2025.06.18 11:08:31.621154 [ 605 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.06.18 11:08:31.648375 [ 605 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.06.18 11:08:31.649650 [ 605 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.06.18 11:08:42.070817 [ 605 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.06.18 11:08:42.072324 [ 605 ] {} KeeperLogStore: Removing all changelogs 2025.06.18 11:08:42.075378 [ 605 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.18 11:08:42.085474 [ 605 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.18 11:08:42.085559 [ 605 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.18 11:08:42.137142 [ 1215 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.18 11:08:42.208264 [ 605 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.06.18 11:08:42.208346 [ 605 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.06.18 11:08:42.567589 [ 605 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.06.18 11:08:55.885121 [ 1588 ] {492ee490-e3c8-4df7-8b19-b0d252146802} executeQuery: Code: 131. DB::Exception: Too large string size (1095207661) in function repeat, maximum is: 1073741824: while executing 'FUNCTION repeat('0.0001048576'_String :: 1, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8))) :: 0) -> repeat('0.0001048576'_String, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8)))) String : 2'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48702) (comment: 01404_roundUpToPowerOfTwoOrZero_safety.sql) (in query: -- repeat() with this length and this number of rows will allocation huge enough region (MSB set), -- which will cause roundUpToPowerOfTwoOrZero() returns 0 for such allocation (before the fix), -- and later repeat() will try to use this memory and will got SIGSEGV. SELECT repeat('0.0001048576', number * (number * (number * 255))) FROM numbers(65535);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000001bda664c 5. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bd9063b 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:55.887085 [ 1588 ] {492ee490-e3c8-4df7-8b19-b0d252146802} TCPHandler: Code: 131. DB::Exception: Too large string size (1095207661) in function repeat, maximum is: 1073741824: while executing 'FUNCTION repeat('0.0001048576'_String :: 1, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8))) :: 0) -> repeat('0.0001048576'_String, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8)))) String : 2'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000001bda664c 5. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bd9063b 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.038695 [ 1587 ] {35c4aeb3-4b2c-4f89-b173-2877c40ea32c} executeQuery: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48694) (comment: 02788_current_schemas_function.sql) (in query: SELECT current_schemas(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionCurrentSchemas::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dd8d669 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:08:56.039922 [ 1587 ] {35c4aeb3-4b2c-4f89-b173-2877c40ea32c} TCPHandler: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionCurrentSchemas::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dd8d669 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:08:56.401857 [ 1590 ] {b6e90065-e217-40ec-859b-b9c216c8733b} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.402594 [ 1590 ] {b6e90065-e217-40ec-859b-b9c216c8733b} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.489182 [ 1590 ] {03edd039-a0fa-4c8d-8668-b5ba33c7a518} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2, 'goodbye' = 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.489693 [ 1590 ] {03edd039-a0fa-4c8d-8668-b5ba33c7a518} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.519049 [ 1395 ] {af8c42f6-ed34-4f2f-8e55-d2432c0603b3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_dz80ujlf.t_async_inserts_logs FORMAT Values' with query id c7434723-5a15-41aa-b8e6-7f52e4ce66e0. DB::Exception: Cannot parse input: expected '(' before: 'qqqqqq': at row 0 2025.06.18 11:08:56.519053 [ 1391 ] {4b6430f2-6ff4-479b-ac45-8f965243220c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_dz80ujlf.t_async_inserts_logs FORMAT JSONEachRow' with query id d1f1bff2-0e96-409b-8bf3-5b1db2594ec8. DB::Exception: Cannot parse input: expected '{' before: 'qqqqqq': (at row 1) 2025.06.18 11:08:56.677866 [ 1589 ] {test_jo7gn188_TEST02132KILL_QUERY1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48734) (comment: 02136_kill_scalar_queries.sh) (in query: select (SELECT max(number) from system.numbers) + 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.679455 [ 1589 ] {test_jo7gn188_TEST02132KILL_QUERY1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.744305 [ 1587 ] {e0081624-bf78-45db-8754-ed45df0da9ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48694) (comment: 02788_current_schemas_function.sql) (in query: SELECT current_schemas();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.744967 [ 1587 ] {e0081624-bf78-45db-8754-ed45df0da9ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.780130 [ 1590 ] {26520184-56fd-4b23-aac6-2d0b46ed38ac} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum8('' = 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.780699 [ 1590 ] {26520184-56fd-4b23-aac6-2d0b46ed38ac} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.798626 [ 1590 ] {b0e356bb-dcd4-41eb-9b9f-d4f8d2b83d8f} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum16('' = 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.799171 [ 1590 ] {b0e356bb-dcd4-41eb-9b9f-d4f8d2b83d8f} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.815757 [ 1590 ] {256182a6-30f6-4a48-a9f6-21a1dff7d8ac} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test MODIFY COLUMN x UInt64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.816233 [ 1590 ] {256182a6-30f6-4a48-a9f6-21a1dff7d8ac} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.833151 [ 1590 ] {1ec26a97-4fc3-477f-8576-6cedcb3b3910} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test MODIFY COLUMN x String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.833944 [ 1590 ] {1ec26a97-4fc3-477f-8576-6cedcb3b3910} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.850408 [ 612 ] {c7434723-5a15-41aa-b8e6-7f52e4ce66e0} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '(' before: 'qqqqqq': at row 0: While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39040) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO t_async_inserts_logs VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadHelpers.h:1704: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x000000003b6d80fb 5. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::read() @ 0x000000003b6d4603 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 7. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 9. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 11. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.852821 [ 612 ] {c7434723-5a15-41aa-b8e6-7f52e4ce66e0} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' before: 'qqqqqq': at row 0: While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadHelpers.h:1704: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x000000003b6d80fb 5. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::read() @ 0x000000003b6d4603 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 7. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 9. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 11. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:08:56.852864 [ 1590 ] {b41c7a71-7e6f-495e-86e2-630bb270fb3b} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test MODIFY COLUMN x Nullable(Int64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.853444 [ 1590 ] {b41c7a71-7e6f-495e-86e2-630bb270fb3b} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3502: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a91c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.855690 [ 1588 ] {d1f1bff2-0e96-409b-8bf3-5b1db2594ec8} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'qqqqqq': (at row 1) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39034) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO t_async_inserts_logs FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b265983 5. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:56.856728 [ 1588 ] {d1f1bff2-0e96-409b-8bf3-5b1db2594ec8} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'qqqqqq': (at row 1) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b265983 5. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:08:57.257840 [ 1590 ] {d4850e28-4b32-44c1-83e3-ad0724138cac} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key x column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test RENAME COLUMN x TO z;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975835a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:57.258426 [ 1590 ] {d4850e28-4b32-44c1-83e3-ad0724138cac} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key x column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975835a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:57.270472 [ 1590 ] {0dfc0fee-c1ae-4858-b0f4-0ee9b28985da} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key y column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test RENAME COLUMN y TO z;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975835a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:57.270960 [ 1590 ] {0dfc0fee-c1ae-4858-b0f4-0ee9b28985da} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key y column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975835a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:57.727736 [ 1590 ] {5442b97b-20d6-4cea-b783-2bb3f02573ed} executeQuery: Code: 47. DB::Exception: Missing columns: 'x' while processing query: 'x', required columns: 'x' 'x'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038196ba7 6. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038195703 7. ./build_docker/./src/Storages/AlterCommands.cpp:1187: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003809141c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:57.728357 [ 1590 ] {5442b97b-20d6-4cea-b783-2bb3f02573ed} TCPHandler: Code: 47. DB::Exception: Missing columns: 'x' while processing query: 'x', required columns: 'x' 'x'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038196ba7 6. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038195703 7. ./build_docker/./src/Storages/AlterCommands.cpp:1187: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003809141c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:58.184719 [ 1590 ] {ece49a77-ed6c-4e17-83c2-889f2a6767a0} executeQuery: Code: 47. DB::Exception: Missing columns: 'y' while processing query: 'y', required columns: 'y' 'y'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48726) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: ALTER TABLE test DROP COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038196ba7 6. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038195703 7. ./build_docker/./src/Storages/AlterCommands.cpp:1171: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090f2f 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:58.185384 [ 1590 ] {ece49a77-ed6c-4e17-83c2-889f2a6767a0} TCPHandler: Code: 47. DB::Exception: Missing columns: 'y' while processing query: 'y', required columns: 'y' 'y'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038196ba7 6. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038195703 7. ./build_docker/./src/Storages/AlterCommands.cpp:1171: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090f2f 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:58.810537 [ 1391 ] {23dc6e39-542c-43fa-b7d0-2f99ce83e84d} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 368.00 B) in table 'test_dz80ujlf.t_async_inserts_logs (c5b394ec-2afb-433a-9f32-a16a17dc8e94)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO test_dz80ujlf.t_async_inserts_logs FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae75d5f 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:896: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000336532b4 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:58.813118 [ 1391 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_dz80ujlf.t_async_inserts_logs FORMAT Values': Code: 252. DB::Exception: Too many parts (1 with average size of 368.00 B) in table 'test_dz80ujlf.t_async_inserts_logs (c5b394ec-2afb-433a-9f32-a16a17dc8e94)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae75d5f 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:896: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000336532b4 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:08:58.814150 [ 1534 ] {ad902fa6-19b2-46d5-8602-89db96e3bedc} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 368.00 B) in table 'test_dz80ujlf.t_async_inserts_logs (c5b394ec-2afb-433a-9f32-a16a17dc8e94)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39078) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO t_async_inserts_logs VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae75d5f 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:896: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000336532b4 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:08:58.815237 [ 1534 ] {ad902fa6-19b2-46d5-8602-89db96e3bedc} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 368.00 B) in table 'test_dz80ujlf.t_async_inserts_logs (c5b394ec-2afb-433a-9f32-a16a17dc8e94)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae75d5f 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:896: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000336532b4 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:00.019244 [ 1589 ] {baf5c323-01a0-4d6b-923c-612efc084c95} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48958) (comment: 02507_to_unix_timestamp_overflow.sql) (in query: SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_18DataTypeDateTime64ENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES6_RKNS4_9FieldTypeEj @ 0x00000000324f39f9 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUnixTimestamp, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUnixTimestamp, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000093ec924 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUnixTimestamp, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093d753f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:09:00.019964 [ 1589 ] {baf5c323-01a0-4d6b-923c-612efc084c95} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_18DataTypeDateTime64ENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES6_RKNS4_9FieldTypeEj @ 0x00000000324f39f9 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUnixTimestamp, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUnixTimestamp, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000093ec924 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUnixTimestamp, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093d753f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:09:00.085400 [ 1583 ] {c229b5ad-cb8f-4398-9daa-6ca8acebfbd7} executeQuery: Code: 390. DB::Exception: Table `mv` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48984) (comment: 02380_insert_mv_race.sh) (in query: ATTACH TABLE mv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032954a26 5. ./src/Databases/IDatabase.h:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b5c3c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:00.096148 [ 1583 ] {c229b5ad-cb8f-4398-9daa-6ca8acebfbd7} TCPHandler: Code: 390. DB::Exception: Table `mv` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032954a26 5. ./src/Databases/IDatabase.h:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b5c3c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:03.206644 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.261290 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.304109 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.340900 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.367562 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.376376 [ 1583 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.419714 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.424576 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.455715 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.483857 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.553246 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.563978 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.585754 [ 1583 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.625255 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.657871 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.688547 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.705701 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.760804 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.786023 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.795973 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.798577 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.820207 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.823640 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.831561 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.862403 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.870314 [ 1815 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.891578 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.894029 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.898837 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.924474 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.989808 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:03.995786 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.123487 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.174613 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.260887 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.290211 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.333562 [ 1597 ] {2c46eec9-bc53-4bc3-b134-3d662d73036d} executeQuery: Code: 10. DB::Exception: Column `v2` not found in table test_udqj6vjj.mv_extra_columns_dst (2c324380-4f63-4710-a0a3-c2c9eb2d0ffb). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51008) (comment: 01019_materialized_view_select_extra_columns.sql) (in query: SELECT * FROM mv_extra_columns_view;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:213: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x0000000038c3d551 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003bec9776 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a5d37b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a209f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a1ff33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2ce816 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003856ab48 11. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:04.334775 [ 1597 ] {2c46eec9-bc53-4bc3-b134-3d662d73036d} TCPHandler: Code: 10. DB::Exception: Column `v2` not found in table test_udqj6vjj.mv_extra_columns_dst (2c324380-4f63-4710-a0a3-c2c9eb2d0ffb). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:213: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x0000000038c3d551 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003bec9776 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a5d37b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a209f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a1ff33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2ce816 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003856ab48 11. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:04.345472 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.521245 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.606482 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.612952 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.638160 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.646783 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.671689 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.685399 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.753845 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.773462 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.795739 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.805728 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.807353 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.911807 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.923851 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.927798 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.929877 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.948607 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.981003 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:04.988219 [ 1583 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.006701 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.130956 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.132976 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.169368 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.242848 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.304040 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.317980 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.331607 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.382660 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.477154 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.493452 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.539687 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.552249 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.554775 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.555196 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.587947 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.608293 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.616514 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.663550 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.675041 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.689409 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.716340 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.736744 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.764228 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.784743 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.809381 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.823688 [ 1815 ] {5cd126ff-1529-4788-91f4-307bfb44e444} executeQuery: Code: 57. DB::Exception: Table test_cpuhh29w.test_table1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51198) (comment: 02122_4letter_words_stress_zookeeper.sh) (in query: CREATE TABLE test_table1 (`key` UInt64, `value1` UInt8, `value2` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02122_4letter_words_stress_zookeeper_test_cpuhh29w/test_table1', '0') ORDER BY key SETTINGS index_granularity = 64805, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 78, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 163332249, compact_parts_max_granules_to_buffer = 232, compact_parts_merge_max_bytes_to_prefetch_part = 6177936, merge_max_block_size = 15677, old_parts_lifetime = 340., prefer_fetch_merged_part_size_threshold = 472309364, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2565726523, index_granularity_bytes = 1423672, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 56315, primary_key_compress_block_size = 58016), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:05.826817 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.831695 [ 1815 ] {5cd126ff-1529-4788-91f4-307bfb44e444} TCPHandler: Code: 57. DB::Exception: Table test_cpuhh29w.test_table1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:05.832670 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.845882 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.866729 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.869695 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.894243 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.897175 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.913251 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:05.992566 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.014300 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.058913 [ 1583 ] {bcd2ca0f-09ae-453b-86a2-be41da3f069f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.060713 [ 1583 ] {bcd2ca0f-09ae-453b-86a2-be41da3f069f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.085125 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.153406 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.179736 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.188584 [ 1815 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.191789 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.258252 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.278759 [ 1583 ] {0dfe3637-5ed8-4987-8a09-e2acc8f1abbf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.279877 [ 1583 ] {0dfe3637-5ed8-4987-8a09-e2acc8f1abbf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.303142 [ 3810 ] {0dcb12d7-dc5d-4a93-98f3-7273f14db3a7} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT if((rand() % 2) = 0, number, toString(number)) FROM numbers(5). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51126) (comment: 00835_if_generic_case.sql) (in query: SELECT rand() % 2 = 0 ? number : toString(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ed462 4. ./contrib/llvm-project/libcxx/include/vector:1501: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fc4f5 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125dac15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:09:06.304136 [ 3810 ] {0dcb12d7-dc5d-4a93-98f3-7273f14db3a7} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT if((rand() % 2) = 0, number, toString(number)) FROM numbers(5). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ed462 4. ./contrib/llvm-project/libcxx/include/vector:1501: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fc4f5 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125dac15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:09:06.323117 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.337235 [ 1583 ] {b39f3ed8-f8fd-4f63-b39f-e64c65f5bbe0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.339337 [ 1583 ] {b39f3ed8-f8fd-4f63-b39f-e64c65f5bbe0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.393942 [ 1583 ] {3b3b6db8-5c25-48b5-abb2-9c5ae63dec34} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.395272 [ 1583 ] {3b3b6db8-5c25-48b5-abb2-9c5ae63dec34} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.407546 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.444195 [ 1583 ] {cc779cda-927a-4aee-bda0-ede7508e9a47} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.445470 [ 1583 ] {cc779cda-927a-4aee-bda0-ede7508e9a47} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.511498 [ 1583 ] {90d877d5-5aaf-4b99-83bd-ac86a54f3468} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.512901 [ 1583 ] {90d877d5-5aaf-4b99-83bd-ac86a54f3468} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.542809 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.574248 [ 1583 ] {139f73a5-d3b8-40bf-8c9f-e72de3abed27} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.575481 [ 1583 ] {139f73a5-d3b8-40bf-8c9f-e72de3abed27} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.608373 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.620004 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.631600 [ 1583 ] {e13b6d6e-835c-438d-9f21-c7a35c7a42f1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.634130 [ 1583 ] {e13b6d6e-835c-438d-9f21-c7a35c7a42f1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.689839 [ 1583 ] {53560a2a-8d8a-45a9-97ce-33e6f9576fbb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.691989 [ 1583 ] {53560a2a-8d8a-45a9-97ce-33e6f9576fbb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.771660 [ 1583 ] {fc52f4aa-9cdc-4812-954b-39565aa97025} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.772966 [ 1583 ] {fc52f4aa-9cdc-4812-954b-39565aa97025} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.784285 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.802736 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.823758 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.834072 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.841387 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.853549 [ 1583 ] {9e52d805-5a2e-4a2f-8f3a-c7ea57338d44} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.854810 [ 1583 ] {9e52d805-5a2e-4a2f-8f3a-c7ea57338d44} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.899675 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.909504 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.920052 [ 1583 ] {24317e38-c09c-4fae-b5a5-4a211c5805c7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.921043 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.923008 [ 1583 ] {24317e38-c09c-4fae-b5a5-4a211c5805c7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.949871 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.950463 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.970755 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:06.974588 [ 1583 ] {0b6c865c-ab73-400a-afa9-be4e29dd21d7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:06.975857 [ 1583 ] {0b6c865c-ab73-400a-afa9-be4e29dd21d7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.027857 [ 1583 ] {10c81ac3-4dc9-4a85-88a2-e050895f8d10} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.029107 [ 1583 ] {10c81ac3-4dc9-4a85-88a2-e050895f8d10} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.085384 [ 1583 ] {a3280389-4792-4235-a1ba-f686bbd4d22d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.088092 [ 1583 ] {a3280389-4792-4235-a1ba-f686bbd4d22d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.095088 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.115698 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.139061 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.143310 [ 1583 ] {f1b99ad7-a08f-4e0b-b25c-894e87f1a956} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.144515 [ 1583 ] {f1b99ad7-a08f-4e0b-b25c-894e87f1a956} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.198626 [ 1583 ] {b8f8a164-8c93-4872-b020-8fb026cdcc02} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.199826 [ 1583 ] {b8f8a164-8c93-4872-b020-8fb026cdcc02} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.221788 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.263137 [ 1583 ] {a496d934-3ff5-4c09-80df-103979faaeb0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.264410 [ 1583 ] {a496d934-3ff5-4c09-80df-103979faaeb0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.306715 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.322995 [ 1583 ] {3394fbc5-0db2-4096-9a32-583acdc4fb20} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.324314 [ 1583 ] {3394fbc5-0db2-4096-9a32-583acdc4fb20} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.356730 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.385919 [ 1583 ] {507cf5aa-40cf-4439-881c-1592d4a1a6ec} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.387061 [ 1583 ] {507cf5aa-40cf-4439-881c-1592d4a1a6ec} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.405785 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.412575 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.447217 [ 1583 ] {61d4be11-d834-4031-845f-753ed90aa07b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.448478 [ 1583 ] {61d4be11-d834-4031-845f-753ed90aa07b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.497813 [ 1583 ] {dd304ce5-b6a0-4b20-b0f4-42a3c47ae569} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.498973 [ 1583 ] {dd304ce5-b6a0-4b20-b0f4-42a3c47ae569} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.551126 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.565464 [ 1583 ] {22aec6f8-ff66-4e4e-8479-a69d34b6c13b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.566755 [ 1583 ] {22aec6f8-ff66-4e4e-8479-a69d34b6c13b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.588905 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.604338 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.606769 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.624116 [ 1583 ] {d5ec32d2-8f33-44e0-b4ac-a632ab345e3d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.625684 [ 1583 ] {d5ec32d2-8f33-44e0-b4ac-a632ab345e3d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.637156 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.644301 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.685032 [ 1583 ] {10ff3f0a-be0f-4b04-927c-02c81147fb21} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.686568 [ 1583 ] {10ff3f0a-be0f-4b04-927c-02c81147fb21} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.741232 [ 1583 ] {5312ea37-4845-49f9-a463-c57acad5d05b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.743060 [ 1583 ] {5312ea37-4845-49f9-a463-c57acad5d05b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.763522 [ 1590 ] {70526ca9-d190-445c-ab17-5c4b8aa7d651} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51324) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_mutation = 100, index_granularity = 21181, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 334031090, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 18618501, merge_max_block_size = 2367, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 30527709, concurrent_part_removal_threshold = 93, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90813, primary_key_compress_block_size = 8660), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f494 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a273b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.764481 [ 1590 ] {70526ca9-d190-445c-ab17-5c4b8aa7d651} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f494 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a273b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.788681 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.801772 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.813118 [ 1583 ] {9f986fa8-a1a2-40f6-b325-b928d30c59df} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.816254 [ 1583 ] {9f986fa8-a1a2-40f6-b325-b928d30c59df} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.844882 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.863223 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.866455 [ 1583 ] {4c88ac17-6135-40ed-b4d3-a6f685ab8592} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.867800 [ 1583 ] {4c88ac17-6135-40ed-b4d3-a6f685ab8592} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.913146 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.921103 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.922023 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.931419 [ 1583 ] {24389cd7-91da-40ba-9d57-8add20b16f8a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.932665 [ 1583 ] {24389cd7-91da-40ba-9d57-8add20b16f8a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.935498 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.973093 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:07.993564 [ 1583 ] {1e66f21b-9cbb-4282-84aa-c3b56ad28b74} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.996803 [ 1583 ] {1e66f21b-9cbb-4282-84aa-c3b56ad28b74} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:07.998751 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.032733 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.060088 [ 1583 ] {aa44cefb-e1e7-40e9-8624-ed1117a1e8a3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.062523 [ 1583 ] {aa44cefb-e1e7-40e9-8624-ed1117a1e8a3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.075523 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.117878 [ 1583 ] {f721a190-6829-41d9-a1c5-31490146ff7d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.119105 [ 1583 ] {f721a190-6829-41d9-a1c5-31490146ff7d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.133591 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.149737 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.159534 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.182904 [ 1583 ] {1c1d0e69-3c20-4123-ba9c-37c87547c2a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.189343 [ 1583 ] {1c1d0e69-3c20-4123-ba9c-37c87547c2a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.254426 [ 1583 ] {cf39333b-f0dc-4f08-ae3d-fd5bc0499461} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.257623 [ 1583 ] {cf39333b-f0dc-4f08-ae3d-fd5bc0499461} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.288681 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.303020 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.312364 [ 1583 ] {31411484-6e93-4846-8c1a-030fe0f37f42} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.313641 [ 1583 ] {31411484-6e93-4846-8c1a-030fe0f37f42} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.320222 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.333234 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.367260 [ 1583 ] {d676e4bf-1d8c-41ea-9136-ff2c0c5e1a11} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.370199 [ 1583 ] {d676e4bf-1d8c-41ea-9136-ff2c0c5e1a11} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.416059 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.419238 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.419250 [ 1590 ] {3f5460ed-f7e4-417d-9dfe-bd460972d00b} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51324) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_lower_max_size_of_merge = 100, index_granularity = 21181, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 334031090, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 18618501, merge_max_block_size = 2367, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 30527709, concurrent_part_removal_threshold = 93, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90813, primary_key_compress_block_size = 8660), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f5d4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a273b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.421383 [ 1590 ] {3f5460ed-f7e4-417d-9dfe-bd460972d00b} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f5d4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a273b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.432999 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.433527 [ 1583 ] {1b926b30-1d82-46fe-9983-add33eb03bf5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.434830 [ 1583 ] {1b926b30-1d82-46fe-9983-add33eb03bf5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.497990 [ 1583 ] {8f0dd615-9492-43df-b348-cfc82fc85fac} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.499199 [ 1583 ] {8f0dd615-9492-43df-b348-cfc82fc85fac} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.540942 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.559401 [ 1583 ] {bb318ed9-0b7b-4a39-9778-b4764516b74c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.561852 [ 1583 ] {bb318ed9-0b7b-4a39-9778-b4764516b74c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.562336 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.568850 [ 3807 ] {014683f9-1395-4445-a0ab-bd66fecc316d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51362) (comment: 00417_kill_query.sh) (in query: SELECT sleep(1) FROM system.numbers LIMIT 300), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.570575 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.574940 [ 3807 ] {014683f9-1395-4445-a0ab-bd66fecc316d} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.616412 [ 3810 ] {8c7e1106-67d9-403a-9f86-3fa4503ca43f} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51368) (comment: 02540_duplicate_primary_key2.sql) (in query: CREATE TABLE test (`timestamp` DateTime, `latitude` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `longitude` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `xxxx1` LowCardinality(UInt8), `xxxx2` LowCardinality(Nullable(Int16)), `xxxx3` LowCardinality(Nullable(Int16)), `xxxx4` Nullable(Int32), `xxxx5` LowCardinality(Nullable(Int32)), `xxxx6` Nullable(Int32), `xxxx7` Nullable(Int32), `xxxx8` LowCardinality(Int32), `xxxx9` LowCardinality(Nullable(Int16)), `xxxx10` LowCardinality(Nullable(Int16)), `xxxx11` LowCardinality(Nullable(Int16)), `xxxx12` LowCardinality(String), `xxxx13` Nullable(Float32), `xxxx14` LowCardinality(String), `xxxx15` LowCardinality(Nullable(String)), `xxxx16` LowCardinality(String), `xxxx17` LowCardinality(String), `xxxx18` FixedString(19), `xxxx19` FixedString(17), `xxxx20` LowCardinality(UInt8), `xxxx21` LowCardinality(Nullable(Int16)), `xxxx22` LowCardinality(Nullable(Int16)), `xxxx23` LowCardinality(Nullable(Int16)), `xxxx24` LowCardinality(Nullable(Int16)), `xxxx25` LowCardinality(Nullable(Int16)), `xxxx26` LowCardinality(Nullable(Int16)), `xxxx27` Nullable(Float32), `xxxx28` LowCardinality(Nullable(String)), `xxxx29` LowCardinality(String), `xxxx30` LowCardinality(String), `xxxx31` LowCardinality(Nullable(String)), `xxxx32` UInt64, PROJECTION cumsum_projection_simple (SELECT xxxx1, toStartOfInterval(timestamp, toIntervalMonth(1)), toStartOfWeek(timestamp, 8), toStartOfInterval(timestamp, toIntervalDay(1)), xxxx17, xxxx16, xxxx14, xxxx9, xxxx10, xxxx21, xxxx22, xxxx11, sum(multiIf(xxxx21 IS NULL, 0, 1)), sum(multiIf(xxxx22 IS NULL, 0, 1)), sum(multiIf(xxxx23 IS NULL, 0, 1)), max(toStartOfInterval(timestamp, toIntervalDay(1))), max(CAST(CAST(toStartOfInterval(timestamp, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), min(toStartOfInterval(timestamp, toIntervalDay(1))), min(CAST(CAST(toStartOfInterval(timestamp, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), count(), sum(1), COUNTDistinct(xxxx16), COUNTDistinct(xxxx31), COUNTDistinct(xxxx14), COUNTDistinct(CAST(toStartOfInterval(timestamp, toIntervalDay(1)), 'Nullable(DATE)')) GROUP BY xxxx1, toStartOfInterval(timestamp, toIntervalMonth(1)), toStartOfWeek(timestamp, 8), toStartOfInterval(timestamp, toIntervalDay(1)), xxxx1, toStartOfInterval(timestamp, toIntervalMonth(1)), toStartOfWeek(timestamp, 8), toStartOfInterval(timestamp, toIntervalDay(1)), xxxx17, xxxx16, xxxx14, xxxx9, xxxx10, xxxx21, xxxx22, xxxx11)) ENGINE = MergeTree PARTITION BY toYYYYMM(timestamp) ORDER BY (xxxx17, xxxx14, xxxx16, toStartOfDay(timestamp), left(xxxx19, 10), timestamp) SETTINGS index_granularity = 3765, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 172583290, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 12241170, merge_max_block_size = 6748, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7024108183, index_granularity_bytes = 31037596, concurrent_part_removal_threshold = 50, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 9377, primary_key_compress_block_size = 47115), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:207: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x00000000396c196b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bacee 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396be24e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.618041 [ 1583 ] {8139234d-2d97-45d0-96a6-541c6b6b4d1a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.618523 [ 3810 ] {8c7e1106-67d9-403a-9f86-3fa4503ca43f} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:207: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x00000000396c196b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bacee 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396be24e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.620237 [ 1583 ] {8139234d-2d97-45d0-96a6-541c6b6b4d1a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.676507 [ 1583 ] {61afe7d5-b4cd-4040-a684-246caa2954a6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.678977 [ 1583 ] {61afe7d5-b4cd-4040-a684-246caa2954a6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.682922 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.719807 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.734721 [ 1583 ] {61aa07c4-0a3f-4732-ac0b-66450af07549} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.737046 [ 1583 ] {61aa07c4-0a3f-4732-ac0b-66450af07549} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.794711 [ 1583 ] {fbcd3f6e-aa81-4e9d-8c4c-0f0d477c509e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.795853 [ 1583 ] {fbcd3f6e-aa81-4e9d-8c4c-0f0d477c509e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.800133 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.812107 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.835961 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.851921 [ 1583 ] {8039dbe2-d5ec-4240-b54c-f7b38a1f6dc7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.854074 [ 1583 ] {8039dbe2-d5ec-4240-b54c-f7b38a1f6dc7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.874565 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.876200 [ 1828 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.912072 [ 1583 ] {0a55e239-d8b7-4a8a-be43-0d6ab2853392} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.914362 [ 1583 ] {0a55e239-d8b7-4a8a-be43-0d6ab2853392} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.930732 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.932527 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:08.984431 [ 1583 ] {e6e09060-0c93-4ad5-99ae-bab5d9eb1afc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:08.985852 [ 1583 ] {e6e09060-0c93-4ad5-99ae-bab5d9eb1afc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.004652 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.033838 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.044938 [ 1583 ] {3b9d4d82-4449-4d01-8011-4553df6140fd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.047479 [ 1583 ] {3b9d4d82-4449-4d01-8011-4553df6140fd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.078773 [ 1590 ] {5782427c-5324-4aef-80ed-93d21b72c8c9} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51324) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_optimize_entire_partition = 100, index_granularity = 21181, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 334031090, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 18618501, merge_max_block_size = 2367, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 30527709, concurrent_part_removal_threshold = 93, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90813, primary_key_compress_block_size = 8660), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:160: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f73a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a273b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.079637 [ 1590 ] {5782427c-5324-4aef-80ed-93d21b72c8c9} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:160: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f73a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a273b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.100127 [ 1583 ] {79bef593-f0a7-476e-a65e-4a00f18e2da8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.101391 [ 1583 ] {79bef593-f0a7-476e-a65e-4a00f18e2da8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.143685 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.161623 [ 1583 ] {5af53eda-e6f1-47db-b16f-53985a0eae37} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.162816 [ 1583 ] {5af53eda-e6f1-47db-b16f-53985a0eae37} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.166260 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.216480 [ 1583 ] {c47e6611-ae17-4ef2-90ef-a57bdedb5985} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.218975 [ 1583 ] {c47e6611-ae17-4ef2-90ef-a57bdedb5985} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.238674 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.252221 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.274330 [ 1583 ] {398630d9-dad1-4654-b146-203e98cfeef6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.276799 [ 1583 ] {398630d9-dad1-4654-b146-203e98cfeef6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.296514 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.334839 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.339013 [ 1583 ] {4b44ffcd-860a-43f9-9518-317b3bb0597c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.340460 [ 1583 ] {4b44ffcd-860a-43f9-9518-317b3bb0597c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.395363 [ 1583 ] {23f0ac18-6124-4948-ae50-6e4bcff118dc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.396561 [ 1583 ] {23f0ac18-6124-4948-ae50-6e4bcff118dc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.399991 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.418260 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.446917 [ 1583 ] {720965c9-4e1f-467c-bdfe-c824f20269e0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.448090 [ 1583 ] {720965c9-4e1f-467c-bdfe-c824f20269e0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.478955 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.519119 [ 1583 ] {3c6714ac-4983-4b5b-9da0-aedd0249dc87} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.521732 [ 1583 ] {3c6714ac-4983-4b5b-9da0-aedd0249dc87} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.528285 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.539935 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.553315 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.572334 [ 1583 ] {05079a09-401c-471e-becb-756b03ff8a29} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.573716 [ 1583 ] {05079a09-401c-471e-becb-756b03ff8a29} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.608512 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.625745 [ 1590 ] {8126c91a-b66b-42d0-848c-4fd4a9bfb13e} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51324) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: ALTER TABLE mytable_local MODIFY SETTING number_of_free_entries_in_pool_to_execute_mutation = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f494 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x00000000397703d1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a2d17bf 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.626811 [ 1590 ] {8126c91a-b66b-42d0-848c-4fd4a9bfb13e} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x0000000039dd9d6d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000039d7f494 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x00000000397703d1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a2d17bf 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.627779 [ 1583 ] {bd710fa5-22df-4b20-a15c-a83ad63530be} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.629001 [ 1583 ] {bd710fa5-22df-4b20-a15c-a83ad63530be} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.658857 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.678801 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.681576 [ 1583 ] {ab46e74e-5378-42b7-ae16-0129c45ba024} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.682779 [ 1583 ] {ab46e74e-5378-42b7-ae16-0129c45ba024} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.700165 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.735355 [ 1583 ] {275d8c0c-3ff4-4048-be07-d1c653d4f298} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.736721 [ 1583 ] {275d8c0c-3ff4-4048-be07-d1c653d4f298} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.747915 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.786165 [ 1583 ] {25e05351-d7d5-4abd-ae12-4f6f08b85d11} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.787546 [ 1583 ] {25e05351-d7d5-4abd-ae12-4f6f08b85d11} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.834121 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.847731 [ 1583 ] {7ea2a2f5-20f6-45da-9678-bad276319017} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.850778 [ 1583 ] {7ea2a2f5-20f6-45da-9678-bad276319017} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.853878 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.901561 [ 1583 ] {24668eda-e8cf-4c19-b851-ac7de6efdc61} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.902738 [ 1583 ] {24668eda-e8cf-4c19-b851-ac7de6efdc61} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.912396 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.936245 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.943793 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:09.951738 [ 1583 ] {134a12ba-68d7-4e3a-b557-e5679de96598} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:09.953566 [ 1583 ] {134a12ba-68d7-4e3a-b557-e5679de96598} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.002667 [ 1583 ] {eaaee791-f035-4a34-9e7f-71677957fbc7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.004784 [ 1583 ] {eaaee791-f035-4a34-9e7f-71677957fbc7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.038303 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.041365 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.065062 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.075964 [ 1583 ] {4a7a16f6-b71b-4817-9a26-d120b4e171f4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.077166 [ 1583 ] {4a7a16f6-b71b-4817-9a26-d120b4e171f4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.080275 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.125215 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.127202 [ 1583 ] {2ffb0d59-ea6b-4902-a9fb-2572b1f9c654} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.129466 [ 1583 ] {2ffb0d59-ea6b-4902-a9fb-2572b1f9c654} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.146681 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.154750 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.181874 [ 1583 ] {d5789946-1549-4413-b34e-a7d78e2d10af} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.183102 [ 1583 ] {d5789946-1549-4413-b34e-a7d78e2d10af} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.200991 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.209907 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.214869 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.223024 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.230605 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.234907 [ 1583 ] {1331d16b-d876-482f-bbd0-8964778c498e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.236315 [ 1583 ] {1331d16b-d876-482f-bbd0-8964778c498e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.236584 [ 3810 ] {53aca399-2333-46ee-8b7b-babd8d81d8da} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51502) (comment: 00417_kill_query.sh) (in query: SELECT sleep(1) FROM system.numbers LIMIT 301), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.237909 [ 3810 ] {53aca399-2333-46ee-8b7b-babd8d81d8da} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.250647 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.252565 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.282597 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.286236 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.288868 [ 1583 ] {56e57bec-384f-4c1b-8b0e-47d6dea4fd94} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.290143 [ 1583 ] {56e57bec-384f-4c1b-8b0e-47d6dea4fd94} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.311836 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.327350 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.331040 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.343246 [ 1583 ] {8a9dc9d3-3be4-4ec1-a9d7-441b69be070c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.344552 [ 1583 ] {8a9dc9d3-3be4-4ec1-a9d7-441b69be070c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.380729 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.392288 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.397269 [ 1583 ] {0bef49a4-648c-40b9-a25b-4b388e7f4306} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.399708 [ 1583 ] {0bef49a4-648c-40b9-a25b-4b388e7f4306} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.468005 [ 1583 ] {98da4893-a00b-4905-addb-ff21e8644d4a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.469360 [ 1583 ] {98da4893-a00b-4905-addb-ff21e8644d4a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.480775 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.497955 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.524478 [ 1583 ] {d5bfd842-de09-4adc-8b95-a9a6df8696fa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.525692 [ 1583 ] {d5bfd842-de09-4adc-8b95-a9a6df8696fa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.577335 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.588158 [ 1583 ] {e7979680-e068-4ae2-b6c8-6ebb44ba8cde} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.591442 [ 1583 ] {e7979680-e068-4ae2-b6c8-6ebb44ba8cde} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.599662 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.619606 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.657340 [ 1583 ] {a51360e9-06cd-4658-a2f3-f7f96b8d634d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.658689 [ 1583 ] {a51360e9-06cd-4658-a2f3-f7f96b8d634d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.676896 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.713413 [ 1583 ] {f0bd006c-4372-4080-af92-e9a946aa0d9b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.714643 [ 1583 ] {f0bd006c-4372-4080-af92-e9a946aa0d9b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.804766 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.810088 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.812046 [ 1583 ] {9d86f02e-3069-4fe5-9d7f-82608c0c048e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.814253 [ 1583 ] {9d86f02e-3069-4fe5-9d7f-82608c0c048e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.817113 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.828581 [ 1814 ] {822c89d4-2655-400a-902a-2cc5db97fa4e} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51618) (comment: 01097_cyclic_defaults.sql) (in query: CREATE TABLE table_with_cyclic_defaults (a DEFAULT b, b DEFAULT a) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 12. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.829439 [ 1814 ] {822c89d4-2655-400a-902a-2cc5db97fa4e} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 12. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.869026 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.871857 [ 1583 ] {def51acc-995e-43de-ad76-6e8d3911d984} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.873203 [ 1583 ] {def51acc-995e-43de-ad76-6e8d3911d984} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.923628 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.927905 [ 1583 ] {89003cf6-7dff-4101-9288-8c02e9410ecd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.929219 [ 1583 ] {89003cf6-7dff-4101-9288-8c02e9410ecd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.932398 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:10.981761 [ 1583 ] {7c510686-bb97-44fe-bf73-4557cd077b37} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:10.983110 [ 1583 ] {7c510686-bb97-44fe-bf73-4557cd077b37} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.017531 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.039142 [ 1583 ] {77910d8c-f478-4596-9fb0-92d08d22603f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.040428 [ 1583 ] {77910d8c-f478-4596-9fb0-92d08d22603f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.053983 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.119670 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.125802 [ 1583 ] {70ff50c5-d2cd-4e11-ac5b-6c76219333f2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.127108 [ 1583 ] {70ff50c5-d2cd-4e11-ac5b-6c76219333f2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.142440 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.179110 [ 1583 ] {dbe39204-4c80-4ab1-91e1-53b350d13a85} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.180305 [ 1583 ] {dbe39204-4c80-4ab1-91e1-53b350d13a85} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.216222 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.233772 [ 1583 ] {25461ecd-7270-41a0-9b46-ceb6494e94a2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.236154 [ 1583 ] {25461ecd-7270-41a0-9b46-ceb6494e94a2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.288852 [ 1583 ] {2c416ef2-fb3c-4d8b-914e-04e8d5d0ce18} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.290063 [ 1583 ] {2c416ef2-fb3c-4d8b-914e-04e8d5d0ce18} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.304825 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.332409 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.339475 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.348157 [ 1583 ] {3c1a0e6d-9e54-4c59-bd33-a1a9b809c8cb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.350332 [ 1583 ] {3c1a0e6d-9e54-4c59-bd33-a1a9b809c8cb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.363753 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.374644 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.403583 [ 1583 ] {3b32ddef-4ce4-4e95-8b5b-55da39a1d0d1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.405667 [ 1583 ] {3b32ddef-4ce4-4e95-8b5b-55da39a1d0d1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.457756 [ 1814 ] {5439d16d-bb67-4ff0-b13e-daf3463389a5} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51618) (comment: 01097_cyclic_defaults.sql) (in query: CREATE TABLE table_with_cyclic_defaults (a DEFAULT b + 1, b DEFAULT a * a) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 14. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 15. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 17. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 18. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.460488 [ 1814 ] {5439d16d-bb67-4ff0-b13e-daf3463389a5} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 14. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 15. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 17. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 18. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.461289 [ 1583 ] {152162c8-e5df-4c78-b27d-128008af3a71} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.462358 [ 1583 ] {152162c8-e5df-4c78-b27d-128008af3a71} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.491122 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.500430 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.511779 [ 1583 ] {8cd76c87-0231-4538-a224-cf0776298cf0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.511900 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.514653 [ 1583 ] {8cd76c87-0231-4538-a224-cf0776298cf0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.572510 [ 1583 ] {aad901aa-b1fc-4489-a2f1-76684f5e0602} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.574587 [ 1583 ] {aad901aa-b1fc-4489-a2f1-76684f5e0602} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.577452 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.619335 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.634508 [ 1583 ] {02d223f4-a924-43f2-80c2-f802379ea565} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.636742 [ 1583 ] {02d223f4-a924-43f2-80c2-f802379ea565} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.641203 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.688147 [ 1583 ] {8425e79f-3bce-4cfd-b3cb-1d62f4b80174} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.690014 [ 1583 ] {8425e79f-3bce-4cfd-b3cb-1d62f4b80174} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.741697 [ 1583 ] {f4df6e73-7e99-45c3-9642-0db7af563175} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.743967 [ 1583 ] {f4df6e73-7e99-45c3-9642-0db7af563175} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.757090 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.766288 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.770887 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.772222 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.790912 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.793339 [ 1583 ] {8b9fc5e2-0516-4bd9-a210-e21ed3b5b95e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.795759 [ 1583 ] {8b9fc5e2-0516-4bd9-a210-e21ed3b5b95e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.833640 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.849497 [ 1583 ] {3b7c58bb-1437-494d-aa62-bf619f44f153} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.850739 [ 1583 ] {3b7c58bb-1437-494d-aa62-bf619f44f153} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.870436 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.883703 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.903561 [ 1583 ] {f7de9619-5892-4384-a162-1a3b34ebd147} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.904864 [ 1583 ] {f7de9619-5892-4384-a162-1a3b34ebd147} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.950828 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.960068 [ 1583 ] {759968c1-b328-4b33-8c70-739e07163e88} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.960910 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.961376 [ 1583 ] {759968c1-b328-4b33-8c70-739e07163e88} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:11.973080 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.979855 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.982934 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:11.994357 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.012826 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.013711 [ 1583 ] {9bb987c3-2786-4dbe-bfd0-d68d4f38e1a0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.019190 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.019667 [ 1583 ] {9bb987c3-2786-4dbe-bfd0-d68d4f38e1a0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.033087 [ 1815 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx21_27665} executeQuery: Code: 60. DB::Exception: Table test_cu81gxo4.tt does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35192) (in query: truncate table tt), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.035450 [ 1815 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx21_27665} DynamicQueryHandler: Code: 60. DB::Exception: Table test_cu81gxo4.tt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:12.043349 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.071024 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.071672 [ 1583 ] {fb134b28-fb6f-4e6f-97c4-6f1186db5d8c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.073009 [ 1583 ] {fb134b28-fb6f-4e6f-97c4-6f1186db5d8c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.094057 [ 1814 ] {ed9e9a2e-6111-4b2d-9bbe-08b4c04c571b} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51618) (comment: 01097_cyclic_defaults.sql) (in query: CREATE TABLE table_with_cyclic_defaults (a DEFAULT b, b DEFAULT toString(c), c DEFAULT concat(a, '1')) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 14. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 15. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 19. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.094922 [ 1814 ] {ed9e9a2e-6111-4b2d-9bbe-08b4c04c571b} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 14. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 15. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 19. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.125513 [ 1583 ] {3a725c12-3b67-40b9-993f-54579a22918b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.126974 [ 1583 ] {3a725c12-3b67-40b9-993f-54579a22918b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.135547 [ 7729 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.167653 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.174498 [ 1583 ] {113048ae-d3e5-4b50-96f9-8617e84d1604} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.175848 [ 1583 ] {113048ae-d3e5-4b50-96f9-8617e84d1604} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.195450 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.197830 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.230091 [ 1583 ] {6b62c71f-62c3-4937-a137-0261973cf41e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.231336 [ 1583 ] {6b62c71f-62c3-4937-a137-0261973cf41e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.240036 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.244987 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.278019 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.281915 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.283887 [ 1583 ] {803903f0-1957-4711-b096-afe17a585338} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.286165 [ 1583 ] {803903f0-1957-4711-b096-afe17a585338} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.305204 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.316243 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.333755 [ 1583 ] {5f144d77-21d2-4443-bbcb-e9c938dfacd6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.336205 [ 1583 ] {5f144d77-21d2-4443-bbcb-e9c938dfacd6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.345561 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.356798 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.387471 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.389764 [ 1583 ] {0b7a24c8-16ba-4e93-a369-f3ae3e8c03ec} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.391024 [ 1583 ] {0b7a24c8-16ba-4e93-a369-f3ae3e8c03ec} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.423606 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.446891 [ 1583 ] {a8ea98b8-19e7-4779-bcae-acd1455ac5a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.448101 [ 1583 ] {a8ea98b8-19e7-4779-bcae-acd1455ac5a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.464441 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.468636 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.482813 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.501328 [ 1583 ] {fe8d200b-6fa1-4082-9c29-0e6487fcc111} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.502525 [ 1583 ] {fe8d200b-6fa1-4082-9c29-0e6487fcc111} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.509816 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.513463 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.547458 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.567962 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.568071 [ 1583 ] {4c57e691-341e-43a7-9028-ed8aecc34e51} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.569370 [ 1583 ] {4c57e691-341e-43a7-9028-ed8aecc34e51} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.625524 [ 1583 ] {97bd80fb-06be-498b-8ed5-63137360a51c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.628959 [ 1583 ] {97bd80fb-06be-498b-8ed5-63137360a51c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.682693 [ 1583 ] {f48b41a2-2f70-4892-9b96-5262007987b6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.684048 [ 1583 ] {f48b41a2-2f70-4892-9b96-5262007987b6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.688031 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.700986 [ 1814 ] {c99af515-1dfd-4a88-8a70-e63f84a98de7} executeQuery: Code: 174. DB::Exception: Self referencing of `a` to `a`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51618) (comment: 01097_cyclic_defaults.sql) (in query: CREATE TABLE table_with_cyclic_defaults (a DEFAULT b, b DEFAULT c, c DEFAULT a * b) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:90: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003573568d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 12. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 13. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 14. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 16. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 17. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.702104 [ 1814 ] {c99af515-1dfd-4a88-8a70-e63f84a98de7} TCPHandler: Code: 174. DB::Exception: Self referencing of `a` to `a`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:90: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003573568d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 12. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 13. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 14. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 16. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 17. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.717431 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.719569 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.727004 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.737396 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.752298 [ 1583 ] {84f861d5-0498-4311-b9ff-9b08a0e6c981} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.754880 [ 1583 ] {84f861d5-0498-4311-b9ff-9b08a0e6c981} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.784413 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.790841 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.807261 [ 1583 ] {60767557-3dca-4d99-8b15-a0a16525b0b1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.807308 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.808911 [ 1583 ] {60767557-3dca-4d99-8b15-a0a16525b0b1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.815476 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.871015 [ 1583 ] {3295cf28-3190-4aa9-908b-1ee0baf23346} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.872205 [ 1583 ] {3295cf28-3190-4aa9-908b-1ee0baf23346} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.928004 [ 1583 ] {32647a93-e4a1-4976-b2d1-2a38982b9cf2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.929284 [ 1583 ] {32647a93-e4a1-4976-b2d1-2a38982b9cf2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.961819 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.975946 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:12.982160 [ 1583 ] {d2d4e2a5-a85c-4381-b4e2-2dc9e29f2a5c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.984846 [ 1583 ] {d2d4e2a5-a85c-4381-b4e2-2dc9e29f2a5c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:12.986376 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.039046 [ 1583 ] {df15841e-eff4-411b-952e-edd88b6bcf93} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.042854 [ 1583 ] {df15841e-eff4-411b-952e-edd88b6bcf93} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.093120 [ 1583 ] {1c7c65e2-c3a7-409a-bf1b-8f014c4cdb75} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.095676 [ 1583 ] {1c7c65e2-c3a7-409a-bf1b-8f014c4cdb75} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.143299 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.150422 [ 1583 ] {35e1cc16-d51c-4156-b7ef-7c11c1212723} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.151761 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.152050 [ 1583 ] {35e1cc16-d51c-4156-b7ef-7c11c1212723} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.157839 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.184833 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.195127 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.207105 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.210547 [ 1583 ] {fe7fe943-b9f4-470a-84ac-37939c8430a1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.211746 [ 1583 ] {fe7fe943-b9f4-470a-84ac-37939c8430a1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.228836 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.257411 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.266292 [ 1583 ] {e2e05c30-1471-4978-9a55-fda95ac40343} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.267562 [ 1583 ] {e2e05c30-1471-4978-9a55-fda95ac40343} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.269913 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.322998 [ 1583 ] {f4d34c46-4d76-46d3-84fe-a2209407ed1f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.325955 [ 1583 ] {f4d34c46-4d76-46d3-84fe-a2209407ed1f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.347660 [ 1814 ] {89ccdebf-de08-44c6-a434-29eb4cd3e4dc} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51618) (comment: 01097_cyclic_defaults.sql) (in query: CREATE TABLE table_with_cyclic_defaults (a String DEFAULT b, b String DEFAULT a) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 16. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 19. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 20. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:09:13.348428 [ 1814 ] {89ccdebf-de08-44c6-a434-29eb4cd3e4dc} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 16. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 19. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 20. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:09:13.383664 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.387932 [ 1583 ] {a651804e-351f-4939-8c9e-89b0f044200b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.389425 [ 1583 ] {a651804e-351f-4939-8c9e-89b0f044200b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.390285 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.440917 [ 1583 ] {6612fa85-29ae-4522-8900-130b7da5a343} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.442092 [ 1583 ] {6612fa85-29ae-4522-8900-130b7da5a343} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.455239 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.465143 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.492775 [ 1583 ] {07ae728d-614f-4e10-b495-5b03906eef74} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.494006 [ 1583 ] {07ae728d-614f-4e10-b495-5b03906eef74} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.513756 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.536703 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.543663 [ 1583 ] {063d9275-5de7-44b0-a6ee-e8fd7ff506ab} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.544925 [ 1583 ] {063d9275-5de7-44b0-a6ee-e8fd7ff506ab} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.600974 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.601973 [ 1583 ] {4cbc998d-8b34-4d26-b7f2-eed62e534602} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.603456 [ 1583 ] {4cbc998d-8b34-4d26-b7f2-eed62e534602} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.622553 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.624699 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.653395 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.655995 [ 1583 ] {5c373e01-c3b6-4e6e-875c-493a49ad660d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.657515 [ 1583 ] {5c373e01-c3b6-4e6e-875c-493a49ad660d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.667905 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.688866 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.712501 [ 1583 ] {2b01b61d-9c96-41a2-bd76-419b742c508c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.715057 [ 1583 ] {2b01b61d-9c96-41a2-bd76-419b742c508c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.778825 [ 1583 ] {97bb49c7-0c63-47c1-9b3a-59774910f06d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.782669 [ 1583 ] {97bb49c7-0c63-47c1-9b3a-59774910f06d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.791607 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.801619 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.844106 [ 1583 ] {3e3ae1d3-21e0-4528-ab05-a1b7ccbe89b2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.845636 [ 1583 ] {3e3ae1d3-21e0-4528-ab05-a1b7ccbe89b2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.852160 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.879914 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.879934 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.904128 [ 1583 ] {a3497428-f43f-4ee1-955f-2dd8de3b0d33} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.905549 [ 1583 ] {a3497428-f43f-4ee1-955f-2dd8de3b0d33} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.942368 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.953401 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.960504 [ 1583 ] {ec442de3-13a0-462c-aef7-9754ecf28ec4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.963116 [ 1583 ] {ec442de3-13a0-462c-aef7-9754ecf28ec4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.971951 [ 1814 ] {5e54edd1-658f-40e2-a80c-0a6db7170e0f} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51618) (comment: 01097_cyclic_defaults.sql) (in query: ALTER TABLE table_with_cyclic_defaults ADD COLUMN c String DEFAULT b, ADD COLUMN b String DEFAULT c;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 16. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 18. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.972836 [ 1814 ] {5e54edd1-658f-40e2-a80c-0a6db7170e0f} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 16. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 18. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.976805 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:13.984570 [ 1814 ] {96f00285-e112-4753-83ca-ea2e88f39e08} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51618) (comment: 01097_cyclic_defaults.sql) (in query: ALTER TABLE table_with_cyclic_defaults ADD COLUMN b String DEFAULT a, MODIFY COLUMN a DEFAULT b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 16. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 18. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.985324 [ 1814 ] {96f00285-e112-4753-83ca-ea2e88f39e08} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 16. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 18. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:13.986816 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.018300 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.019824 [ 1583 ] {258e84a7-1240-43dc-b58e-855eb50acf85} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.021138 [ 1583 ] {258e84a7-1240-43dc-b58e-855eb50acf85} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.031107 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.076547 [ 1583 ] {305bc37c-30c2-46f6-9f61-16340a7a7b76} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.078104 [ 1583 ] {305bc37c-30c2-46f6-9f61-16340a7a7b76} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.100833 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.103069 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.129293 [ 1583 ] {ce6be263-60e8-4157-a1e8-56fef6f9750d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.131605 [ 1583 ] {ce6be263-60e8-4157-a1e8-56fef6f9750d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.190868 [ 1583 ] {17d63049-71db-4634-88c4-81b9a14ac104} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.192126 [ 1583 ] {17d63049-71db-4634-88c4-81b9a14ac104} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.232488 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.237321 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.247825 [ 1583 ] {9a5d265a-043b-4c41-a3ce-8469094dec05} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.250465 [ 1583 ] {9a5d265a-043b-4c41-a3ce-8469094dec05} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.260428 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.304575 [ 1583 ] {4372f746-f546-4da3-96d1-9797603f04a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.307754 [ 1583 ] {4372f746-f546-4da3-96d1-9797603f04a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.315537 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.372687 [ 1583 ] {caed17d0-2eb1-49bb-a363-ed777594ad53} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.374024 [ 1583 ] {caed17d0-2eb1-49bb-a363-ed777594ad53} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.375928 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.377740 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.395365 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.420494 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.427449 [ 1583 ] {71e9e2c3-b72f-4f09-92ac-38e80385e197} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.429614 [ 1583 ] {71e9e2c3-b72f-4f09-92ac-38e80385e197} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.441233 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.481578 [ 1583 ] {a93ec114-863b-42e7-bc55-43b333db3d6a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.482724 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.483173 [ 1583 ] {a93ec114-863b-42e7-bc55-43b333db3d6a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.511183 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.535235 [ 1583 ] {e7c46d50-fa1d-4575-a864-d76307770268} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.537992 [ 1583 ] {e7c46d50-fa1d-4575-a864-d76307770268} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.589710 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.589823 [ 1583 ] {0fbf550c-bc4d-49dd-a99b-19f8d75b253f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.591254 [ 1583 ] {0fbf550c-bc4d-49dd-a99b-19f8d75b253f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.603957 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.632149 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.633316 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.652566 [ 1583 ] {9b686bd2-e600-4ad2-a552-14d19cd1a81d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.653863 [ 1583 ] {9b686bd2-e600-4ad2-a552-14d19cd1a81d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.680309 [ 3810 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.710346 [ 1583 ] {4fc98290-282d-432d-96fd-24be47fd36d1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.711594 [ 1583 ] {4fc98290-282d-432d-96fd-24be47fd36d1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.767966 [ 1583 ] {660cc8c4-5444-4b02-bc8d-058b06fde4e5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.770870 [ 1583 ] {660cc8c4-5444-4b02-bc8d-058b06fde4e5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.775688 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.801619 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.812101 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.819892 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.822875 [ 1583 ] {6c608088-a05f-41f1-a35f-e06405157c5e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.825690 [ 1583 ] {6c608088-a05f-41f1-a35f-e06405157c5e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.855623 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.879407 [ 1583 ] {76156cd6-c3a6-4ff2-b276-756b9fc69a52} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.880080 [ 1587 ] {10cb7e04-b724-4768-9645-d97baeeddc9a} executeQuery: Code: 57. DB::Exception: Table test_cpuhh29w.test_table6 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41288) (comment: 02122_4letter_words_stress_zookeeper.sh) (in query: CREATE TABLE test_table6 (`key` UInt64, `value1` UInt8, `value2` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02122_4letter_words_stress_zookeeper_test_cpuhh29w/test_table6', '0') ORDER BY key SETTINGS index_granularity = 64805, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 78, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 163332249, compact_parts_max_granules_to_buffer = 232, compact_parts_merge_max_bytes_to_prefetch_part = 6177936, merge_max_block_size = 15677, old_parts_lifetime = 340., prefer_fetch_merged_part_size_threshold = 472309364, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2565726523, index_granularity_bytes = 1423672, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 56315, primary_key_compress_block_size = 58016), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.880718 [ 1583 ] {76156cd6-c3a6-4ff2-b276-756b9fc69a52} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.882517 [ 1587 ] {10cb7e04-b724-4768-9645-d97baeeddc9a} TCPHandler: Code: 57. DB::Exception: Table test_cpuhh29w.test_table6 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.892324 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.912694 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.934481 [ 1583 ] {6580eeb4-cf12-4b5f-a3b2-63161ecc0bbf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.935708 [ 1583 ] {6580eeb4-cf12-4b5f-a3b2-63161ecc0bbf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.949180 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:14.991792 [ 1583 ] {07ea3b5b-d1c1-4f15-8a77-f3502ece3d9e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:14.994094 [ 1583 ] {07ea3b5b-d1c1-4f15-8a77-f3502ece3d9e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.004529 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.016540 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.051272 [ 1583 ] {deb1c2de-c47c-4d29-bd7f-7b7375d81e4a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.053865 [ 1583 ] {deb1c2de-c47c-4d29-bd7f-7b7375d81e4a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.098489 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.107752 [ 1583 ] {231fb79f-e841-4b7e-93bf-eb903cb17fb7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.109490 [ 1583 ] {231fb79f-e841-4b7e-93bf-eb903cb17fb7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.165131 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.165870 [ 1583 ] {3840a688-f2fa-4e7b-82bf-f34159dd2940} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.167260 [ 1583 ] {3840a688-f2fa-4e7b-82bf-f34159dd2940} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.230139 [ 1583 ] {1ca97b27-c521-4268-94b7-32724ea5032f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.231506 [ 1583 ] {1ca97b27-c521-4268-94b7-32724ea5032f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.295047 [ 1583 ] {49d35369-d976-4a0b-9e7c-cab998082859} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.296855 [ 1583 ] {49d35369-d976-4a0b-9e7c-cab998082859} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.366872 [ 1583 ] {530e6b09-e313-4388-91b6-69744e8decf4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.369564 [ 1583 ] {530e6b09-e313-4388-91b6-69744e8decf4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.385914 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.398513 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.429501 [ 1583 ] {77d9ebb0-5288-47aa-b6ba-68c75f645e5e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.430782 [ 1583 ] {77d9ebb0-5288-47aa-b6ba-68c75f645e5e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.474581 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.488702 [ 1583 ] {0c377130-3550-4eb9-8c11-b3d106e86f15} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.489928 [ 1583 ] {0c377130-3550-4eb9-8c11-b3d106e86f15} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.492015 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.600773 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.618288 [ 1583 ] {73dc2482-4384-426a-b1b5-c5a6d71f29ca} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.619915 [ 1583 ] {73dc2482-4384-426a-b1b5-c5a6d71f29ca} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.658121 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.680473 [ 1583 ] {7bf95f98-e226-4b8a-a920-65fb39f312fe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.682061 [ 1583 ] {7bf95f98-e226-4b8a-a920-65fb39f312fe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.734874 [ 1583 ] {5d6285ee-954b-490b-a1b2-14d524a89cba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.736123 [ 1583 ] {5d6285ee-954b-490b-a1b2-14d524a89cba} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.746636 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.759880 [ 3807 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.805744 [ 1597 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.818141 [ 1583 ] {0a8b1d5d-538b-4627-88ba-b1b51df92005} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.819678 [ 1583 ] {0a8b1d5d-538b-4627-88ba-b1b51df92005} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.839386 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:15.883886 [ 1583 ] {b0c61035-afbe-4646-bec2-b930b1decaa4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.885549 [ 1583 ] {b0c61035-afbe-4646-bec2-b930b1decaa4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.947340 [ 1583 ] {910ed19b-6a76-4b48-b6aa-1471b29327dd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.950032 [ 1583 ] {910ed19b-6a76-4b48-b6aa-1471b29327dd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:15.996283 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.009054 [ 1583 ] {f3b188ef-acf6-476f-81a5-a2e5033e69d7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.010889 [ 1583 ] {f3b188ef-acf6-476f-81a5-a2e5033e69d7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.075917 [ 1583 ] {e7d21c7c-c60c-4ca5-8fc8-2415d1fbb711} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.078546 [ 1583 ] {e7d21c7c-c60c-4ca5-8fc8-2415d1fbb711} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.100917 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.110052 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.121503 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.139201 [ 1583 ] {09313992-b2b5-4853-a298-7bfb8cf7c18d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.142049 [ 1583 ] {09313992-b2b5-4853-a298-7bfb8cf7c18d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.207457 [ 1583 ] {e89a6b3e-51dd-45e1-9e6a-5265ae563b03} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.211006 [ 1583 ] {e89a6b3e-51dd-45e1-9e6a-5265ae563b03} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.277499 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.285289 [ 1583 ] {a0434fdb-7978-4d49-9e31-1195ab2fa33d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.288634 [ 1583 ] {a0434fdb-7978-4d49-9e31-1195ab2fa33d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.338109 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.353196 [ 1583 ] {e731b5c1-b5a8-41bf-a24c-6ad3bc2c0d62} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.354611 [ 1583 ] {e731b5c1-b5a8-41bf-a24c-6ad3bc2c0d62} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.409558 [ 1583 ] {4a2ba1c1-f6ea-489d-bd66-9f5c646d069b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.410531 [ 1583 ] {4a2ba1c1-f6ea-489d-bd66-9f5c646d069b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.434661 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.435823 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.470273 [ 1583 ] {4a0bedd6-115a-47ca-8052-274967c789f4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.472078 [ 1583 ] {4a0bedd6-115a-47ca-8052-274967c789f4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.473427 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.538801 [ 1583 ] {8e4f191e-b9d9-43ff-9d5d-b9b7896e1760} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.541847 [ 1583 ] {8e4f191e-b9d9-43ff-9d5d-b9b7896e1760} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.564889 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.593617 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.604315 [ 1583 ] {f666bfdc-9b46-4b40-9002-97b875821a60} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.605891 [ 1583 ] {f666bfdc-9b46-4b40-9002-97b875821a60} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.613562 [ 1534 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.670679 [ 1583 ] {c54406e1-7305-4cb7-89d1-23ea61273e91} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.671952 [ 1583 ] {c54406e1-7305-4cb7-89d1-23ea61273e91} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.727376 [ 1583 ] {9fd0ca76-c663-4e3d-9ffa-41f7a2eee3c1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.729683 [ 1583 ] {9fd0ca76-c663-4e3d-9ffa-41f7a2eee3c1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.731424 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.791188 [ 1583 ] {c37f8694-32a9-4ecb-ab4c-e5a7506c40ec} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.792893 [ 1583 ] {c37f8694-32a9-4ecb-ab4c-e5a7506c40ec} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.841197 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.853020 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.855461 [ 1583 ] {6e71e900-608a-4cf1-925f-e95368d3c48c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.858515 [ 1583 ] {6e71e900-608a-4cf1-925f-e95368d3c48c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.915846 [ 1583 ] {ef238686-2a72-4cbe-b593-acf9b4d6f673} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.919511 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.922454 [ 1583 ] {ef238686-2a72-4cbe-b593-acf9b4d6f673} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.935672 [ 612 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.942338 [ 1587 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:16.987420 [ 1583 ] {2a716b4f-9093-4c61-b335-6a51a711f081} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:16.988877 [ 1583 ] {2a716b4f-9093-4c61-b335-6a51a711f081} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.000713 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.073391 [ 1583 ] {6a6e7397-e5a5-414f-ae70-cfe9d544ff11} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.076368 [ 1583 ] {6a6e7397-e5a5-414f-ae70-cfe9d544ff11} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.084207 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.132285 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.144313 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.160244 [ 1583 ] {431707d7-9265-4890-bf76-f5bc035e3b87} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.161792 [ 1583 ] {431707d7-9265-4890-bf76-f5bc035e3b87} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.171399 [ 1590 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.177692 [ 1815 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.229364 [ 1583 ] {c4c96aa9-6c1a-4f57-84c3-bde212a7a4d4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.232236 [ 1583 ] {c4c96aa9-6c1a-4f57-84c3-bde212a7a4d4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.290566 [ 1583 ] {12154d6d-2dac-41df-a459-61cc92f26b47} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.292436 [ 1583 ] {12154d6d-2dac-41df-a459-61cc92f26b47} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.327877 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.343557 [ 1583 ] {25f969d1-e390-4a40-b170-0d1b7c7961f2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.346255 [ 1583 ] {25f969d1-e390-4a40-b170-0d1b7c7961f2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.373648 [ 610 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.389401 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.398063 [ 3810 ] {f9990f65-026e-4cd8-b508-3ce28a44f64e} executeQuery: Code: 117. DB::Exception: The arrays in column 'vec' must not be empty. Did you try to INSERT default values?. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41336) (comment: 02354_vector_search_bugs.sql) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:0: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x0000000039b9d3d4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399cb554 6. ./src/Core/Block.h:25: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399a50f7 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x00000000399a8205 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:450: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000399aab30 9. ./contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e209b1 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f0220c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 14. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 20. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.402036 [ 3810 ] {f9990f65-026e-4cd8-b508-3ce28a44f64e} TCPHandler: Code: 117. DB::Exception: The arrays in column 'vec' must not be empty. Did you try to INSERT default values?. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:0: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x0000000039b9d3d4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399cb554 6. ./src/Core/Block.h:25: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399a50f7 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x00000000399a8205 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:450: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000399aab30 9. ./contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e209b1 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f0220c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 14. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 20. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.412888 [ 1583 ] {d5b3baad-2885-4fec-95df-1109514413f2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.414635 [ 1583 ] {d5b3baad-2885-4fec-95df-1109514413f2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.472058 [ 3810 ] {3feb28fc-46cc-47bf-95a3-be01b921bce2} executeQuery: Code: 117. DB::Exception: The arrays in column 'vec' must not be empty. Did you try to INSERT default values?. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41336) (comment: 02354_vector_search_bugs.sql) (in query: INSERT INTO tab (id) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:0: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x0000000039b9d3d4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399cb554 6. ./src/Core/Block.h:25: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399a50f7 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x00000000399a8205 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:450: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000399aab30 9. ./contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e209b1 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f0220c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 14. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 20. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.473905 [ 3810 ] {3feb28fc-46cc-47bf-95a3-be01b921bce2} TCPHandler: Code: 117. DB::Exception: The arrays in column 'vec' must not be empty. Did you try to INSERT default values?. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:0: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x0000000039b9d3d4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399cb554 6. ./src/Core/Block.h:25: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x00000000399a50f7 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x00000000399a8205 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:450: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000399aab30 9. ./contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e209b1 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f0220c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 14. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 20. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.475820 [ 1583 ] {88a16aee-0ad1-497b-81ed-8a8ca78b6ffa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.477236 [ 1583 ] {88a16aee-0ad1-497b-81ed-8a8ca78b6ffa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.509286 [ 1815 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.532934 [ 1583 ] {b0d8353f-4f34-4f71-be94-58ee063740d7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.534191 [ 1583 ] {b0d8353f-4f34-4f71-be94-58ee063740d7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.599791 [ 1583 ] {a817d589-5a1f-4c14-ac7f-ba6a0ab974cf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.603049 [ 1583 ] {a817d589-5a1f-4c14-ac7f-ba6a0ab974cf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.656905 [ 1583 ] {67d616d1-4455-4ee8-a223-42f3f2e00afd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.658427 [ 1583 ] {67d616d1-4455-4ee8-a223-42f3f2e00afd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.712121 [ 1583 ] {491c23be-1fbb-4006-8983-572a5357531a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.715049 [ 1583 ] {491c23be-1fbb-4006-8983-572a5357531a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.782274 [ 1583 ] {88a47b47-91bb-4011-8c47-0028097c5f32} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.783731 [ 1583 ] {88a47b47-91bb-4011-8c47-0028097c5f32} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.836778 [ 1588 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.845204 [ 1583 ] {43e0a5ec-49db-47a4-aa1e-29e2aacb8790} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.846577 [ 1583 ] {43e0a5ec-49db-47a4-aa1e-29e2aacb8790} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.919861 [ 1583 ] {905ccadd-1a41-488a-9023-5bd7fa758710} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.921131 [ 1583 ] {905ccadd-1a41-488a-9023-5bd7fa758710} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.964799 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.978409 [ 1583 ] {34210b5c-d13b-469e-af45-b6bc358fb5bd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.980454 [ 1583 ] {34210b5c-d13b-469e-af45-b6bc358fb5bd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:17.985660 [ 1814 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:17.990065 [ 1589 ] {} KeeperTCPHandler: Not enabled four letter command wchc 2025.06.18 11:09:18.033640 [ 1583 ] {93967354-c367-400a-9c45-8b849919345a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.035955 [ 1583 ] {93967354-c367-400a-9c45-8b849919345a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.091982 [ 1583 ] {155026af-31b6-4fde-8d0b-fc3102ba48f8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.093865 [ 1583 ] {155026af-31b6-4fde-8d0b-fc3102ba48f8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.154681 [ 1583 ] {3bd661ac-c624-4ab7-b9c9-deccc852d7c8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.155952 [ 1583 ] {3bd661ac-c624-4ab7-b9c9-deccc852d7c8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.207246 [ 1583 ] {28e74a5c-628d-459f-aef3-e053ce48a588} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.208600 [ 1583 ] {28e74a5c-628d-459f-aef3-e053ce48a588} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.259143 [ 1583 ] {a9489119-aa05-4e37-a2da-2414f37772b4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.260933 [ 1583 ] {a9489119-aa05-4e37-a2da-2414f37772b4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.314775 [ 1583 ] {568202f5-cd90-45cc-8433-f4d567959ffe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.316026 [ 1583 ] {568202f5-cd90-45cc-8433-f4d567959ffe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.373093 [ 1583 ] {a19bef03-0522-4596-87ee-15ad1736ba18} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.374543 [ 1583 ] {a19bef03-0522-4596-87ee-15ad1736ba18} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.430491 [ 1583 ] {7c2a51f9-a716-4f5e-923a-97f259ee090c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.431807 [ 1583 ] {7c2a51f9-a716-4f5e-923a-97f259ee090c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.488178 [ 1583 ] {4c647635-4319-44c5-aa96-ee65da3fb327} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.489467 [ 1583 ] {4c647635-4319-44c5-aa96-ee65da3fb327} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.540324 [ 1583 ] {622d3529-49a1-4669-b607-58b8e2d10e44} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.541545 [ 1583 ] {622d3529-49a1-4669-b607-58b8e2d10e44} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.597148 [ 1583 ] {dea49df2-27d6-47f3-b0a4-fd4c39b0bafd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.598680 [ 1583 ] {dea49df2-27d6-47f3-b0a4-fd4c39b0bafd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.655572 [ 1583 ] {9a5ce88f-d5a4-4ad3-94eb-0676b1cdb964} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.656892 [ 1583 ] {9a5ce88f-d5a4-4ad3-94eb-0676b1cdb964} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.714122 [ 1583 ] {742e3470-984b-4e48-b871-a67073732cda} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.715781 [ 1583 ] {742e3470-984b-4e48-b871-a67073732cda} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.771016 [ 1583 ] {316fccab-2a1d-430f-b15b-759c71d6e570} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.772462 [ 1583 ] {316fccab-2a1d-430f-b15b-759c71d6e570} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.775548 [ 3810 ] {2232fbf3-d818-4897-82ed-f4bfb4383099} executeQuery: Code: 190. DB::Exception: Arguments of function arrayL2Distance have different array sizes: 2 and 3: while executing 'FUNCTION L2Distance(__table1.vec : 0, _CAST([0., 2.]_Array(Float64), 'Array(Float64)'_String) :: 2) -> L2Distance(__table1.vec, _CAST([0., 2.]_Array(Float64), 'Array(Float64)'_String)) Float64 : 1'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41336) (comment: 02354_vector_search_bugs.sql) (in query: WITH [0.0, 2.0] AS reference_vec SELECT id, vec, L2Distance(vec, reference_vec) FROM tab ORDER BY L2Distance(vec, reference_vec) LIMIT 3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, unsigned long&&) @ 0x000000001cf9f797 4. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000001d3f9c5c 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000001d3f558f 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000001d2fdc4d 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000001d1c7981 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d1c4aae 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca9ebc2 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.779803 [ 3810 ] {2232fbf3-d818-4897-82ed-f4bfb4383099} TCPHandler: Code: 190. DB::Exception: Arguments of function arrayL2Distance have different array sizes: 2 and 3: while executing 'FUNCTION L2Distance(__table1.vec : 0, _CAST([0., 2.]_Array(Float64), 'Array(Float64)'_String) :: 2) -> L2Distance(__table1.vec, _CAST([0., 2.]_Array(Float64), 'Array(Float64)'_String)) Float64 : 1'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, unsigned long&&) @ 0x000000001cf9f797 4. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000001d3f9c5c 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000001d3f558f 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000001d2fdc4d 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000001d1c7981 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d1c4aae 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca9ebc2 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.826745 [ 1583 ] {08b8394b-8123-4a19-a431-2788ce0be044} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.828048 [ 1583 ] {08b8394b-8123-4a19-a431-2788ce0be044} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.882416 [ 1583 ] {fb184b43-1427-4d9b-ba91-962e7bee2bd8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.883736 [ 1583 ] {fb184b43-1427-4d9b-ba91-962e7bee2bd8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.938105 [ 1583 ] {7fb75478-e7a7-4400-aa97-5c63e0652b59} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.939474 [ 1583 ] {7fb75478-e7a7-4400-aa97-5c63e0652b59} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:18.994126 [ 1583 ] {3a69c8de-1fa9-4ebb-9b5c-6e45b6919a74} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.082812 [ 1583 ] {3a69c8de-1fa9-4ebb-9b5c-6e45b6919a74} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.137751 [ 1583 ] {1878e124-b13c-461d-b0b2-bdc971f764c7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.139059 [ 1583 ] {1878e124-b13c-461d-b0b2-bdc971f764c7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.189763 [ 1583 ] {a01b51cd-99ab-47ba-88e2-e0d2e65239db} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.191262 [ 1583 ] {a01b51cd-99ab-47ba-88e2-e0d2e65239db} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.241805 [ 1583 ] {5755931a-23dc-4f77-9cda-2e3ac911c113} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.243143 [ 1583 ] {5755931a-23dc-4f77-9cda-2e3ac911c113} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.301276 [ 1583 ] {7162e754-6f07-4ae3-ad6c-20e4017c6e4a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.302587 [ 1583 ] {7162e754-6f07-4ae3-ad6c-20e4017c6e4a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.358422 [ 1583 ] {a3573844-ce79-4449-aba0-1b47ac985c4d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.359647 [ 1583 ] {a3573844-ce79-4449-aba0-1b47ac985c4d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.411990 [ 1583 ] {dc3bd035-8fe1-4ec7-9398-ff3d199a632b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.413494 [ 1583 ] {dc3bd035-8fe1-4ec7-9398-ff3d199a632b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.466623 [ 1583 ] {05cf123f-aef5-43a0-9dcc-e7430e8e99c1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.468063 [ 1583 ] {05cf123f-aef5-43a0-9dcc-e7430e8e99c1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.522285 [ 1583 ] {1917e3c2-7bb7-407c-9c32-d3373a3423e4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.523573 [ 1583 ] {1917e3c2-7bb7-407c-9c32-d3373a3423e4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.575934 [ 1583 ] {f3370226-84dc-4c78-a41a-495be18f206f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.577351 [ 1583 ] {f3370226-84dc-4c78-a41a-495be18f206f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.632715 [ 1583 ] {be6d7840-ebfe-4672-9b12-e64358840a33} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.634305 [ 1583 ] {be6d7840-ebfe-4672-9b12-e64358840a33} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.683577 [ 1583 ] {268e0818-d986-4650-b688-cad3c1a4bce5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.684947 [ 1583 ] {268e0818-d986-4650-b688-cad3c1a4bce5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.737183 [ 1583 ] {e2d5c27e-ee36-4ac9-b734-b63dfcc0586e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.738427 [ 1583 ] {e2d5c27e-ee36-4ac9-b734-b63dfcc0586e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.797158 [ 1583 ] {5a8c0084-dbc0-4232-b93b-0708edd122a8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.798676 [ 1583 ] {5a8c0084-dbc0-4232-b93b-0708edd122a8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.860507 [ 1583 ] {e1b1ed49-01ed-4342-a590-ea72d3433f7a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.861824 [ 1583 ] {e1b1ed49-01ed-4342-a590-ea72d3433f7a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.916764 [ 1583 ] {4626fd61-1a6e-4947-9b3e-c99f7999d7f6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.918091 [ 1583 ] {4626fd61-1a6e-4947-9b3e-c99f7999d7f6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.972069 [ 1583 ] {3a3e447e-32cf-49da-9976-c9af40f96b7f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:19.973499 [ 1583 ] {3a3e447e-32cf-49da-9976-c9af40f96b7f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.036373 [ 1583 ] {77e6ac6e-0ae2-446d-a9e2-5dab9e2ca1f6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.037931 [ 1583 ] {77e6ac6e-0ae2-446d-a9e2-5dab9e2ca1f6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.089132 [ 1583 ] {24109a7c-5e66-467e-84b9-c0951832acfe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.090503 [ 1583 ] {24109a7c-5e66-467e-84b9-c0951832acfe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.136792 [ 1583 ] {ffe77bd4-fd8a-4971-9860-058ee4a4b55c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.137981 [ 1583 ] {ffe77bd4-fd8a-4971-9860-058ee4a4b55c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.192949 [ 1583 ] {0a034b81-041b-42d6-9726-12cf047edf24} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.194389 [ 1583 ] {0a034b81-041b-42d6-9726-12cf047edf24} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.250932 [ 1583 ] {282d5d06-126f-403f-945d-07b8058350ca} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.252431 [ 1583 ] {282d5d06-126f-403f-945d-07b8058350ca} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.306267 [ 1583 ] {550c3fca-c29c-47e4-a361-90f521343a83} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.307492 [ 1583 ] {550c3fca-c29c-47e4-a361-90f521343a83} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.360885 [ 1583 ] {a580ca5c-8cec-4359-b06b-89a112547396} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.362770 [ 1583 ] {a580ca5c-8cec-4359-b06b-89a112547396} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.420127 [ 1583 ] {c0e53d04-2bd6-4722-a5d8-a401aa5c7dcd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.421875 [ 1583 ] {c0e53d04-2bd6-4722-a5d8-a401aa5c7dcd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.479641 [ 1583 ] {35325fe8-4817-4cad-930e-8f1e72c51f65} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.480842 [ 1583 ] {35325fe8-4817-4cad-930e-8f1e72c51f65} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.537296 [ 1583 ] {746da494-6120-48dc-aa07-82ec8259df3a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.538571 [ 1583 ] {746da494-6120-48dc-aa07-82ec8259df3a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.589312 [ 1583 ] {e1c11a1e-1ee9-4374-951e-a211a192fc7f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.590539 [ 1583 ] {e1c11a1e-1ee9-4374-951e-a211a192fc7f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.591371 [ 3807 ] {b7ff3de2-48e6-4d7a-a6e2-acf0aa7664c8} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41594) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, 'a Tuple(b UInt32)', '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.592397 [ 3807 ] {b7ff3de2-48e6-4d7a-a6e2-acf0aa7664c8} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.607275 [ 3807 ] {4446abf7-136d-48f0-8d22-2e6b6ccf5e94} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41594) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.608052 [ 3807 ] {4446abf7-136d-48f0-8d22-2e6b6ccf5e94} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.621255 [ 3807 ] {45820832-22f0-4235-a702-f5a57745a6c5} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41594) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2, "b" : 3}, "c" : 42}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.622341 [ 3807 ] {45820832-22f0-4235-a702-f5a57745a6c5} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.644651 [ 1583 ] {bb48fc04-edd0-4bd5-86c1-5fdbb5d4ccb4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.645975 [ 1583 ] {bb48fc04-edd0-4bd5-86c1-5fdbb5d4ccb4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.714077 [ 1583 ] {bff7ca69-84af-4bd6-b514-ebd0a542abc4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.715913 [ 1583 ] {bff7ca69-84af-4bd6-b514-ebd0a542abc4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.752909 [ 3807 ] {9701c22b-ac8e-4d86-9b25-aa006ba2eb9d} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41594) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : "Hello"}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.753815 [ 3807 ] {9701c22b-ac8e-4d86-9b25-aa006ba2eb9d} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.770083 [ 1583 ] {ea012c08-003d-47e5-a42e-5df5a98561b6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.771324 [ 1583 ] {ea012c08-003d-47e5-a42e-5df5a98561b6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.778685 [ 3807 ] {203d64cb-340c-463b-b26d-a8e864d11852} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41594) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : {"c" : "Hello"}}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.779475 [ 3807 ] {203d64cb-340c-463b-b26d-a8e864d11852} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000032868ef8 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003285dea8 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:515: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032850349 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000003276ccfc 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b2243c8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b264dcc 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b2655e7 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:09:20.820020 [ 1583 ] {042ba3ee-b949-4294-8cdb-16c66cfa962f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.821248 [ 1583 ] {042ba3ee-b949-4294-8cdb-16c66cfa962f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.869678 [ 1583 ] {9eb021bc-0c77-482d-9745-8feccf503811} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.870959 [ 1583 ] {9eb021bc-0c77-482d-9745-8feccf503811} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.924360 [ 1583 ] {a9be0c32-5ecc-48bd-aecd-6745d6884683} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.925726 [ 1583 ] {a9be0c32-5ecc-48bd-aecd-6745d6884683} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.990881 [ 1583 ] {1701ce98-450f-4a9c-95e3-8cc0cca828a9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:20.993098 [ 1583 ] {1701ce98-450f-4a9c-95e3-8cc0cca828a9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.054618 [ 1583 ] {11d36738-9185-4cae-97d0-ecd46d515094} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.056243 [ 1583 ] {11d36738-9185-4cae-97d0-ecd46d515094} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.108003 [ 1583 ] {533a8fc8-f9ef-4a66-af95-be781e333fb7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.109333 [ 1583 ] {533a8fc8-f9ef-4a66-af95-be781e333fb7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.164547 [ 1583 ] {0ad7578a-cb27-4e47-8083-425db27ee25f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.165996 [ 1583 ] {0ad7578a-cb27-4e47-8083-425db27ee25f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.176280 [ 1590 ] {e164fea3-4954-44ce-9fcc-1886d47b82a4} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41622). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41622) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.185967 [ 1590 ] {e164fea3-4954-44ce-9fcc-1886d47b82a4} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41622). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.186414 [ 1590 ] {e164fea3-4954-44ce-9fcc-1886d47b82a4} TCPHandler: Client has gone away. 2025.06.18 11:09:21.219201 [ 1583 ] {4e7263f2-1fa0-41ef-beed-c1723a447de2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.220504 [ 1583 ] {4e7263f2-1fa0-41ef-beed-c1723a447de2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.293462 [ 1583 ] {1cf7334c-b2f6-43f7-8af6-3bbd86d14bf7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.294886 [ 1583 ] {1cf7334c-b2f6-43f7-8af6-3bbd86d14bf7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.352699 [ 1583 ] {fa04e50c-0189-42fa-845e-764a89e3754a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.354034 [ 1583 ] {fa04e50c-0189-42fa-845e-764a89e3754a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.413990 [ 1583 ] {a5acacee-462f-45e2-a4d0-6e5065ee6893} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.415334 [ 1583 ] {a5acacee-462f-45e2-a4d0-6e5065ee6893} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.466036 [ 1583 ] {5527ea4a-3168-42bf-9ba0-4dc02b37c1c7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.467338 [ 1583 ] {5527ea4a-3168-42bf-9ba0-4dc02b37c1c7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.514183 [ 1583 ] {578b9b6f-fb36-40aa-b642-e46244cabb92} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.515532 [ 1583 ] {578b9b6f-fb36-40aa-b642-e46244cabb92} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.562129 [ 1583 ] {4dec00ad-d6a2-46ab-9a7f-414bc90c452b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.563348 [ 1583 ] {4dec00ad-d6a2-46ab-9a7f-414bc90c452b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.612365 [ 1583 ] {bf0d129a-82e1-4c18-8359-fb98efdf1832} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.613730 [ 1583 ] {bf0d129a-82e1-4c18-8359-fb98efdf1832} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.643903 [ 1597 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx41_29397} executeQuery: Code: 650. DB::Exception: Serialization error: Transaction (35, 36, 92427cc0-299d-4553-b6c7-a452802d57ca) tried to remove data part all_2_2_0 from test_cu81gxo4.tt (64629ea8-b9b1-4739-895a-48afe8fc6783), but it's locked by another transaction (TID: (35, 37, 92427cc0-299d-4553-b6c7-a452802d57ca), TIDH: 13758903232289347189) which is currently removing this part. (SERIALIZATION_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35312) (in query: truncate table tt), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x00000000356074e7 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:62: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x00000000355ff052 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000034f4a463 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000034f4a19c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x0000000039785ef9 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003a322651 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492bdf5 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 15. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 16. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.645329 [ 1597 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx41_29397} DynamicQueryHandler: Code: 650. DB::Exception: Serialization error: Transaction (35, 36, 92427cc0-299d-4553-b6c7-a452802d57ca) tried to remove data part all_2_2_0 from test_cu81gxo4.tt (64629ea8-b9b1-4739-895a-48afe8fc6783), but it's locked by another transaction (TID: (35, 37, 92427cc0-299d-4553-b6c7-a452802d57ca), TIDH: 13758903232289347189) which is currently removing this part. (SERIALIZATION_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x00000000356074e7 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:62: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x00000000355ff052 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000034f4a463 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000034f4a19c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x0000000039785ef9 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003a322651 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492bdf5 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 15. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 16. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:21.662921 [ 1583 ] {8b5fa3e4-c88d-47c0-b925-129c79e30a5c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.664175 [ 1583 ] {8b5fa3e4-c88d-47c0-b925-129c79e30a5c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.713810 [ 1583 ] {2641ff47-0145-4e12-be81-ecaae1a70c1d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.715056 [ 1583 ] {2641ff47-0145-4e12-be81-ecaae1a70c1d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.763653 [ 1583 ] {f98de2ca-d145-456e-8d11-fb5dffe01ba5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.764960 [ 1583 ] {f98de2ca-d145-456e-8d11-fb5dffe01ba5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.815051 [ 1583 ] {7cd925a8-9bbf-4f53-b962-93d521310633} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.816490 [ 1583 ] {7cd925a8-9bbf-4f53-b962-93d521310633} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.865256 [ 1583 ] {7ec7c1ad-f13a-459a-bac4-60909db46848} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.866460 [ 1583 ] {7ec7c1ad-f13a-459a-bac4-60909db46848} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.912642 [ 1583 ] {e5cf66a3-41d4-4e27-a8e7-1982a7602434} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.914135 [ 1583 ] {e5cf66a3-41d4-4e27-a8e7-1982a7602434} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.969681 [ 1583 ] {9556e7e8-b452-4243-ac04-e971aa5e8b49} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:21.971152 [ 1583 ] {9556e7e8-b452-4243-ac04-e971aa5e8b49} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.024899 [ 1583 ] {0763a151-dec1-4f6b-b7b8-51acd3c90241} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.026172 [ 1583 ] {0763a151-dec1-4f6b-b7b8-51acd3c90241} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.029965 [ 1597 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx41_21896} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60918) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000358d31f9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000358d1a93 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.031814 [ 1597 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx41_21896} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000358d31f9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000358d1a93 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:22.079666 [ 1583 ] {2f0c6200-dce3-4767-8bd0-e835cf9d86e3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.081107 [ 1583 ] {2f0c6200-dce3-4767-8bd0-e835cf9d86e3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.133864 [ 1583 ] {b7ce08b8-6bcc-4e02-bd1a-ffcba79fce97} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.135320 [ 1583 ] {b7ce08b8-6bcc-4e02-bd1a-ffcba79fce97} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.189353 [ 1583 ] {0bf4bd7d-7ed2-43f2-b22f-ee9bffcd6e0f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.190785 [ 1583 ] {0bf4bd7d-7ed2-43f2-b22f-ee9bffcd6e0f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.244924 [ 1583 ] {802a6802-103a-4991-95cb-c64859d58132} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.246364 [ 1583 ] {802a6802-103a-4991-95cb-c64859d58132} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.299167 [ 1583 ] {ac31ae7e-2bec-4eae-b437-c5c0cf5784e0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.300460 [ 1583 ] {ac31ae7e-2bec-4eae-b437-c5c0cf5784e0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.355336 [ 1583 ] {fde062b6-acaa-4c97-9512-ca4e1e2a885a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.356756 [ 1583 ] {fde062b6-acaa-4c97-9512-ca4e1e2a885a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.415868 [ 1583 ] {8183011e-9027-497b-99ac-9951b4976c93} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.417812 [ 1583 ] {8183011e-9027-497b-99ac-9951b4976c93} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.472801 [ 1583 ] {ed1a6529-b0a1-499c-a8a1-7badf02b3fb0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.474121 [ 1583 ] {ed1a6529-b0a1-499c-a8a1-7badf02b3fb0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.527246 [ 1583 ] {074e4ab0-1392-4b3d-b34b-038c17d80c44} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.528570 [ 1583 ] {074e4ab0-1392-4b3d-b34b-038c17d80c44} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.582812 [ 1583 ] {f72c3895-12fd-4703-ab42-9b4356a5c645} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.584599 [ 1583 ] {f72c3895-12fd-4703-ab42-9b4356a5c645} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.643706 [ 1583 ] {33da759b-4bb6-4198-881d-457578526de0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.645425 [ 1583 ] {33da759b-4bb6-4198-881d-457578526de0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.700902 [ 1583 ] {0c8bddcc-0022-4f20-a40e-006f9565297e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.702201 [ 1583 ] {0c8bddcc-0022-4f20-a40e-006f9565297e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.754923 [ 1583 ] {81c5ae7d-5d74-4e34-b20e-396ec5b3123c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.756439 [ 1583 ] {81c5ae7d-5d74-4e34-b20e-396ec5b3123c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.808496 [ 1583 ] {7f91f650-c4d0-4be1-a43e-5bcb27f70c9b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.809909 [ 1583 ] {7f91f650-c4d0-4be1-a43e-5bcb27f70c9b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.877431 [ 1583 ] {2306f3bd-8f0f-4884-9c7a-9cee696c3341} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.878824 [ 1583 ] {2306f3bd-8f0f-4884-9c7a-9cee696c3341} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.932556 [ 1583 ] {81f46a9d-9cf0-4854-a20e-1b1ecfd9f157} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.934009 [ 1583 ] {81f46a9d-9cf0-4854-a20e-1b1ecfd9f157} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.985168 [ 1583 ] {5869effd-ed90-4d58-8788-59438afacdca} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:22.986575 [ 1583 ] {5869effd-ed90-4d58-8788-59438afacdca} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.036823 [ 1583 ] {4be99622-7762-42fa-a0eb-91d12588dbf1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.038152 [ 1583 ] {4be99622-7762-42fa-a0eb-91d12588dbf1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.096758 [ 1583 ] {825b3bd9-65dd-430a-be25-811a8c18b34a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.098337 [ 1583 ] {825b3bd9-65dd-430a-be25-811a8c18b34a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.158726 [ 1583 ] {eee0ea80-82c5-46b0-bbdd-b166fe00aea5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.160478 [ 1583 ] {eee0ea80-82c5-46b0-bbdd-b166fe00aea5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.221695 [ 1583 ] {53a12c46-aa70-4595-97a2-73592628e298} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.223708 [ 1583 ] {53a12c46-aa70-4595-97a2-73592628e298} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.280397 [ 1583 ] {5268e186-9754-4f49-9322-051bcd70a434} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.282464 [ 1583 ] {5268e186-9754-4f49-9322-051bcd70a434} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.343548 [ 1583 ] {cd74fb25-ded7-46ea-8654-491092aedcd2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.345272 [ 1583 ] {cd74fb25-ded7-46ea-8654-491092aedcd2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.415066 [ 1583 ] {5d402d0c-a5b2-4e2f-b727-984bed2b9ea7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.417010 [ 1583 ] {5d402d0c-a5b2-4e2f-b727-984bed2b9ea7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.475451 [ 1583 ] {30f79492-6d4a-4507-8e56-70d2cc2201fd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.476780 [ 1583 ] {30f79492-6d4a-4507-8e56-70d2cc2201fd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.525640 [ 1583 ] {fd54beee-aed9-4a62-b658-33a04ba14f97} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.526915 [ 1583 ] {fd54beee-aed9-4a62-b658-33a04ba14f97} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.581507 [ 1583 ] {4b0405a9-a41a-4bd6-88d2-5c2667dfbe1f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.582774 [ 1583 ] {4b0405a9-a41a-4bd6-88d2-5c2667dfbe1f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.642742 [ 1583 ] {94538ae4-c9c1-4a79-8d03-0a7bbc859d7c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.644265 [ 1583 ] {94538ae4-c9c1-4a79-8d03-0a7bbc859d7c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.694995 [ 1583 ] {1a46d489-dab0-49ad-b541-74ef9e818d89} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.696488 [ 1583 ] {1a46d489-dab0-49ad-b541-74ef9e818d89} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.744425 [ 1583 ] {ce3cdc43-c15c-4e9a-9f29-7b9670572bef} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.745952 [ 1583 ] {ce3cdc43-c15c-4e9a-9f29-7b9670572bef} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.791456 [ 1583 ] {8881db2b-9be8-4d63-89cb-f8d23005d64e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.792622 [ 1583 ] {8881db2b-9be8-4d63-89cb-f8d23005d64e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.832931 [ 1583 ] {df7929bd-dddc-4dac-8d6b-61da6cd521c8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.834569 [ 1583 ] {df7929bd-dddc-4dac-8d6b-61da6cd521c8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.877774 [ 1583 ] {166f292a-3185-48f1-b370-ec20d0d6ee7d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.878963 [ 1583 ] {166f292a-3185-48f1-b370-ec20d0d6ee7d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.919983 [ 1583 ] {47e9ef2f-00b7-4866-bbc3-7dce37a68834} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.921052 [ 1583 ] {47e9ef2f-00b7-4866-bbc3-7dce37a68834} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.962988 [ 1583 ] {a92fc5f3-3265-4c8b-be54-605a7ed0e6c6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:23.964193 [ 1583 ] {a92fc5f3-3265-4c8b-be54-605a7ed0e6c6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.009946 [ 1583 ] {774923db-68db-4c82-a97f-1890aa6aa0e1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.011093 [ 1583 ] {774923db-68db-4c82-a97f-1890aa6aa0e1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.057247 [ 1583 ] {7c4813a0-c5fb-4080-90ea-0b945e117695} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.058723 [ 1583 ] {7c4813a0-c5fb-4080-90ea-0b945e117695} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.115574 [ 1583 ] {f157f674-83e9-48bd-a108-a804ae7c9b7d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.116954 [ 1583 ] {f157f674-83e9-48bd-a108-a804ae7c9b7d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.171339 [ 1583 ] {14db74a5-92e8-44fb-a8fc-7e8662842cf2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.172882 [ 1583 ] {14db74a5-92e8-44fb-a8fc-7e8662842cf2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.225637 [ 1583 ] {5fe9ef8d-9e0e-4877-bce5-3b44a9bbc619} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.227168 [ 1583 ] {5fe9ef8d-9e0e-4877-bce5-3b44a9bbc619} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.280393 [ 1583 ] {c2fe5ea9-d372-4578-8020-989d54bb1fc0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.281648 [ 1583 ] {c2fe5ea9-d372-4578-8020-989d54bb1fc0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.339621 [ 1583 ] {1b2e0984-3ea3-4722-a6ba-c39f9a18835e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.341402 [ 1583 ] {1b2e0984-3ea3-4722-a6ba-c39f9a18835e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.401780 [ 1583 ] {c7d688f6-0f8e-44db-8fd3-22f245443f71} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.402252 [ 1587 ] {7c60dea3-24a6-4c58-b2be-eb9384552654} executeQuery: Code: 43. DB::Exception: First parameter for aggregate function groupConcat should be string. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35012) (comment: 03156_group_concat.sql) (in query: SELECT groupConcat(123)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:248: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b661d96 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.403426 [ 1587 ] {7c60dea3-24a6-4c58-b2be-eb9384552654} TCPHandler: Code: 43. DB::Exception: First parameter for aggregate function groupConcat should be string. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:248: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b661d96 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.403484 [ 1583 ] {c7d688f6-0f8e-44db-8fd3-22f245443f71} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.459792 [ 1583 ] {22b90318-1235-4d5f-b5bb-81a8a3ff4281} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.461168 [ 1583 ] {22b90318-1235-4d5f-b5bb-81a8a3ff4281} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.511987 [ 1583 ] {3f98d76e-e56e-483a-8bd3-81e586f019a6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.513286 [ 1583 ] {3f98d76e-e56e-483a-8bd3-81e586f019a6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.567556 [ 1583 ] {b185a2d6-1da2-4541-a9af-8acbb1a6c4df} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.568941 [ 1583 ] {b185a2d6-1da2-4541-a9af-8acbb1a6c4df} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.621649 [ 1583 ] {66c4be64-1e38-4f69-a77b-6e5c6c9971e4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.622970 [ 1583 ] {66c4be64-1e38-4f69-a77b-6e5c6c9971e4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.675936 [ 1583 ] {d514245b-4949-4d52-8acc-9747a747be13} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.677248 [ 1583 ] {d514245b-4949-4d52-8acc-9747a747be13} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.730332 [ 1583 ] {2ac69563-4814-490c-b1ea-2e56f56cb265} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.731722 [ 1583 ] {2ac69563-4814-490c-b1ea-2e56f56cb265} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.785075 [ 1583 ] {954b877e-e95b-4ac3-a4d5-d22759cb7347} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.786358 [ 1583 ] {954b877e-e95b-4ac3-a4d5-d22759cb7347} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.837756 [ 1583 ] {bddb758f-892e-4dff-9955-5d7a9d4f15c0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.839028 [ 1583 ] {bddb758f-892e-4dff-9955-5d7a9d4f15c0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.890669 [ 1583 ] {3f84d6ba-60b9-4521-85c1-4450e0ae6cdd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.891942 [ 1583 ] {3f84d6ba-60b9-4521-85c1-4450e0ae6cdd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.945269 [ 1583 ] {64c47223-b04b-4407-9193-19ad254e1c51} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:24.946526 [ 1583 ] {64c47223-b04b-4407-9193-19ad254e1c51} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.000503 [ 1583 ] {3de23daf-9e57-4240-8c0d-0d12fbdb3079} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.002124 [ 1583 ] {3de23daf-9e57-4240-8c0d-0d12fbdb3079} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.056095 [ 1583 ] {c089d355-80fb-4986-9841-348d70639549} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.057591 [ 1583 ] {c089d355-80fb-4986-9841-348d70639549} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.058510 [ 1587 ] {d40380c3-5729-485d-aa4f-984c71984a4c} executeQuery: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35012) (comment: 03156_group_concat.sql) (in query: SELECT groupConcat(',', '3')(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:0: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b661f01 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.059430 [ 1587 ] {d40380c3-5729-485d-aa4f-984c71984a4c} TCPHandler: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:0: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b661f01 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.112248 [ 1583 ] {e30e2f84-034f-434c-a09b-ba50349e5cd4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.113846 [ 1583 ] {e30e2f84-034f-434c-a09b-ba50349e5cd4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.164582 [ 1583 ] {64af6699-68c2-4968-9b37-27b863af100b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.165932 [ 1583 ] {64af6699-68c2-4968-9b37-27b863af100b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.216294 [ 1583 ] {71087875-8502-4903-ac50-4958901084c4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.217721 [ 1583 ] {71087875-8502-4903-ac50-4958901084c4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.288791 [ 1583 ] {ba28486c-8fee-4ddc-9eea-909275b0d8a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.290952 [ 1583 ] {ba28486c-8fee-4ddc-9eea-909275b0d8a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.344184 [ 1583 ] {9960587c-fa46-4e1d-9d5d-acc854ab0348} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.345786 [ 1583 ] {9960587c-fa46-4e1d-9d5d-acc854ab0348} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.403886 [ 1583 ] {ef444f1f-edb6-40a0-8cc3-30b3c5ad6fd6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.405401 [ 1583 ] {ef444f1f-edb6-40a0-8cc3-30b3c5ad6fd6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.470494 [ 1583 ] {bca3f470-e858-4707-bd17-49709e8620d2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.471831 [ 1583 ] {bca3f470-e858-4707-bd17-49709e8620d2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.524687 [ 1583 ] {e6a4b54c-d9ca-4852-b551-fcf3417a6199} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.525937 [ 1583 ] {e6a4b54c-d9ca-4852-b551-fcf3417a6199} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.580931 [ 1583 ] {aafd6304-dc4c-4fac-b658-939da7ddc6f8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.582452 [ 1583 ] {aafd6304-dc4c-4fac-b658-939da7ddc6f8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.636556 [ 1583 ] {731e398d-a8a6-4ac7-b347-da507f43c707} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.638113 [ 1583 ] {731e398d-a8a6-4ac7-b347-da507f43c707} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.690635 [ 1583 ] {87c263d3-45f1-4182-aedd-b666af0e6e82} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.692375 [ 1583 ] {87c263d3-45f1-4182-aedd-b666af0e6e82} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.693739 [ 1587 ] {7f43f32e-ee72-4499-90a8-070867fdc204} executeQuery: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: 0. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35012) (comment: 03156_group_concat.sql) (in query: SELECT groupConcat(',', 0)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long&) @ 0x000000002b66e78d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:0: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b660b73 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.694575 [ 1587 ] {7f43f32e-ee72-4499-90a8-070867fdc204} TCPHandler: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: 0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long&) @ 0x000000002b66e78d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:0: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b660b73 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.706338 [ 1587 ] {ec43c102-8131-482c-a7c6-3c25f095c301} executeQuery: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: -1. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35012) (comment: 03156_group_concat.sql) (in query: SELECT groupConcat(',', -1)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long&) @ 0x000000002b66e78d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:0: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b660b73 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.707810 [ 1587 ] {ec43c102-8131-482c-a7c6-3c25f095c301} TCPHandler: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: -1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long&) @ 0x000000002b66e78d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:0: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b660b73 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.749185 [ 1583 ] {08f4b87a-e732-41cd-b4f4-d896108a4069} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.751050 [ 1583 ] {08f4b87a-e732-41cd-b4f4-d896108a4069} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.803979 [ 1583 ] {7820f64e-8357-489d-8623-8f0dde09ff97} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.805662 [ 1583 ] {7820f64e-8357-489d-8623-8f0dde09ff97} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.861795 [ 1583 ] {f46de57c-8fa9-4e88-acbd-6e57181754b4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.863268 [ 1583 ] {f46de57c-8fa9-4e88-acbd-6e57181754b4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.920152 [ 1583 ] {4036f3bd-e083-499c-a4b3-7d988ef2d1e6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.921735 [ 1583 ] {4036f3bd-e083-499c-a4b3-7d988ef2d1e6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.977265 [ 1583 ] {4d32fd20-e1eb-4dce-88ba-3ce03fec55e9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:25.978780 [ 1583 ] {4d32fd20-e1eb-4dce-88ba-3ce03fec55e9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.035553 [ 1583 ] {e517c281-0409-4f2d-8075-f2e292730489} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.037121 [ 1583 ] {e517c281-0409-4f2d-8075-f2e292730489} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.085288 [ 1583 ] {046f47ed-d2d7-4f50-b815-fae4adba23f5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.086811 [ 1583 ] {046f47ed-d2d7-4f50-b815-fae4adba23f5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.139749 [ 1583 ] {41c40ab6-ee00-450c-b043-63431fcba414} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.141167 [ 1583 ] {41c40ab6-ee00-450c-b043-63431fcba414} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.189366 [ 1583 ] {6ab4920e-d9b3-4bde-94e5-30e359a1d1f4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.190786 [ 1583 ] {6ab4920e-d9b3-4bde-94e5-30e359a1d1f4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.254686 [ 1583 ] {3633661d-ca81-4023-8af9-edc77767e6bf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.256437 [ 1583 ] {3633661d-ca81-4023-8af9-edc77767e6bf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.306401 [ 1583 ] {5be97a60-b141-4430-889c-0d9a8f5e9457} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.307627 [ 1583 ] {5be97a60-b141-4430-889c-0d9a8f5e9457} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.354610 [ 1583 ] {a3ce7f0c-96d4-47c4-a53c-c8c94673663f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.355858 [ 1583 ] {a3ce7f0c-96d4-47c4-a53c-c8c94673663f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.365663 [ 1587 ] {b8f98d4d-498a-4231-8c01-c8dd05c69d24} executeQuery: Code: 34. DB::Exception: Incorrect number of parameters for aggregate function groupConcat, should be 0, 1 or 2, got: 3. (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35012) (comment: 03156_group_concat.sql) (in query: SELECT groupConcat(',', 3, 3)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:241: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b661c21 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.366491 [ 1587 ] {b8f98d4d-498a-4231-8c01-c8dd05c69d24} TCPHandler: Code: 34. DB::Exception: Incorrect number of parameters for aggregate function groupConcat, should be 0, 1 or 2, got: 3. (TOO_MANY_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:241: DB::(anonymous namespace)::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b661c21 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.407198 [ 1583 ] {c2ffa8a1-cb46-4d27-9486-ed7ce6ec5d77} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.408541 [ 1583 ] {c2ffa8a1-cb46-4d27-9486-ed7ce6ec5d77} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.459169 [ 1583 ] {59d254e6-f56e-4d2d-abc1-7107449fa225} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.460559 [ 1583 ] {59d254e6-f56e-4d2d-abc1-7107449fa225} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.510017 [ 1583 ] {6ea2bdbb-cd7f-49af-8f46-4998354b2689} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.511393 [ 1583 ] {6ea2bdbb-cd7f-49af-8f46-4998354b2689} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.566112 [ 1583 ] {3c13ed67-ae43-4c59-82d5-30249e4e1752} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.567754 [ 1583 ] {3c13ed67-ae43-4c59-82d5-30249e4e1752} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.618543 [ 1583 ] {e0418aa2-0f85-44d2-8366-421d982a7cd0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.620279 [ 1583 ] {e0418aa2-0f85-44d2-8366-421d982a7cd0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.674375 [ 1583 ] {356b54e2-c701-42fc-aa84-8e3064cf46eb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.675680 [ 1583 ] {356b54e2-c701-42fc-aa84-8e3064cf46eb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.723838 [ 1583 ] {b3c1ddfa-d93a-496d-b406-e910144b187a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.725104 [ 1583 ] {b3c1ddfa-d93a-496d-b406-e910144b187a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.771255 [ 1583 ] {87414120-f262-4524-8dfb-41ae77abf992} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.772542 [ 1583 ] {87414120-f262-4524-8dfb-41ae77abf992} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.826477 [ 1583 ] {a8596ea0-ed4f-4cd9-b4e1-4671647837a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.827850 [ 1583 ] {a8596ea0-ed4f-4cd9-b4e1-4671647837a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.877407 [ 1583 ] {a10fc220-fe14-46db-9fa3-45894d793050} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.878650 [ 1583 ] {a10fc220-fe14-46db-9fa3-45894d793050} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.931164 [ 1583 ] {1e5c22bb-a5a1-4922-b5a2-24762c42dfa8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.932522 [ 1583 ] {1e5c22bb-a5a1-4922-b5a2-24762c42dfa8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.983819 [ 1583 ] {079a28f7-31df-4557-9005-6ee19e1014ec} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:26.985206 [ 1583 ] {079a28f7-31df-4557-9005-6ee19e1014ec} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.039200 [ 1583 ] {7dda7f5c-48ce-4b18-bc3d-6b17f235b93a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.040844 [ 1583 ] {7dda7f5c-48ce-4b18-bc3d-6b17f235b93a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.098299 [ 1583 ] {4d1d4a71-5795-4a61-8d29-5d2f594bd0d9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.099950 [ 1583 ] {4d1d4a71-5795-4a61-8d29-5d2f594bd0d9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.155749 [ 1583 ] {afcc5d62-0abb-47cb-80ec-c7509f9b0221} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.157318 [ 1583 ] {afcc5d62-0abb-47cb-80ec-c7509f9b0221} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.212557 [ 1583 ] {d151170a-0f9e-40bb-ba47-f17852919b1c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.213882 [ 1583 ] {d151170a-0f9e-40bb-ba47-f17852919b1c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.265501 [ 1583 ] {2a89d306-2a5a-4e91-9f39-79dc3b6d0444} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.266836 [ 1583 ] {2a89d306-2a5a-4e91-9f39-79dc3b6d0444} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.333308 [ 1583 ] {26d062a2-ad58-46da-83bd-35349cf47098} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.335347 [ 1583 ] {26d062a2-ad58-46da-83bd-35349cf47098} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.394576 [ 1583 ] {c59268c1-0e0f-4978-b9e8-d6006d5a64c3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.396030 [ 1583 ] {c59268c1-0e0f-4978-b9e8-d6006d5a64c3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.452503 [ 1583 ] {94d8f1a6-915f-424e-9ba3-fcf776c1f2d4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.454091 [ 1583 ] {94d8f1a6-915f-424e-9ba3-fcf776c1f2d4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.505980 [ 1583 ] {17be2270-d4b4-4361-9a35-e26726ce5e93} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.507555 [ 1583 ] {17be2270-d4b4-4361-9a35-e26726ce5e93} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.560506 [ 1583 ] {3b9a0760-b6ed-44d4-a187-b9453f186c1b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.562116 [ 1583 ] {3b9a0760-b6ed-44d4-a187-b9453f186c1b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.614226 [ 1583 ] {f53a84b0-45c7-484f-b167-174562cea9ac} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.615786 [ 1583 ] {f53a84b0-45c7-484f-b167-174562cea9ac} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.670209 [ 1583 ] {14f6ddd7-68e1-441d-abed-77283dee659a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.671732 [ 1583 ] {14f6ddd7-68e1-441d-abed-77283dee659a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.730350 [ 1583 ] {1a7aa3e3-6897-421a-adc2-13d6079cd85d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.731697 [ 1583 ] {1a7aa3e3-6897-421a-adc2-13d6079cd85d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.783603 [ 1583 ] {537ac014-a85c-44e8-bd9d-d35fd946e076} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.784925 [ 1583 ] {537ac014-a85c-44e8-bd9d-d35fd946e076} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.838070 [ 1583 ] {c31f9b49-d568-408a-be25-1970b6564d35} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.839561 [ 1583 ] {c31f9b49-d568-408a-be25-1970b6564d35} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.888821 [ 1583 ] {d652f363-f5b4-4852-bfce-639111193a88} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.890172 [ 1583 ] {d652f363-f5b4-4852-bfce-639111193a88} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.943172 [ 1583 ] {4d8a05f2-0223-48f5-9667-ed6810e0a615} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:27.944768 [ 1583 ] {4d8a05f2-0223-48f5-9667-ed6810e0a615} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.000771 [ 1583 ] {298dc49e-0261-4469-b4c3-8a29afa54766} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.002382 [ 1583 ] {298dc49e-0261-4469-b4c3-8a29afa54766} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.058022 [ 1583 ] {a6af0a2b-2313-4a68-86aa-73ea1ea54247} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.059682 [ 1583 ] {a6af0a2b-2313-4a68-86aa-73ea1ea54247} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.109738 [ 1583 ] {1f1046d4-1c32-4edd-a3d1-0132c295c1f4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.110956 [ 1583 ] {1f1046d4-1c32-4edd-a3d1-0132c295c1f4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.159677 [ 1583 ] {b2276899-e272-4ea3-bc4e-3d688f9c9898} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.161122 [ 1583 ] {b2276899-e272-4ea3-bc4e-3d688f9c9898} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.209667 [ 1583 ] {3613fa6a-a5fb-44c8-ac7c-ef95872bee93} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.211065 [ 1583 ] {3613fa6a-a5fb-44c8-ac7c-ef95872bee93} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.261374 [ 1583 ] {f32587c0-e65a-43e0-8e20-38946ada26d0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.262794 [ 1583 ] {f32587c0-e65a-43e0-8e20-38946ada26d0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.316952 [ 1583 ] {fe93c732-c940-4fcb-9635-1e82fa494351} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.318813 [ 1583 ] {fe93c732-c940-4fcb-9635-1e82fa494351} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.373356 [ 1583 ] {ef78f57a-0108-439a-b27a-f236f67ab081} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.374650 [ 1583 ] {ef78f57a-0108-439a-b27a-f236f67ab081} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.423870 [ 1583 ] {c03f5858-61c4-4ea2-937b-91963af05aa1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.425232 [ 1583 ] {c03f5858-61c4-4ea2-937b-91963af05aa1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.475970 [ 1583 ] {f57cef06-42ff-4dc1-9e6c-577d494ad3ba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.477383 [ 1583 ] {f57cef06-42ff-4dc1-9e6c-577d494ad3ba} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.529505 [ 1583 ] {f1639260-e52e-473d-a195-8c62436ac7fe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.530811 [ 1583 ] {f1639260-e52e-473d-a195-8c62436ac7fe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.581258 [ 1583 ] {a8ca376f-0d77-4857-b825-e67d19ea5ee5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.582544 [ 1583 ] {a8ca376f-0d77-4857-b825-e67d19ea5ee5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.629506 [ 1583 ] {dba1a51f-c994-421a-9685-1e269d7313a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.630769 [ 1583 ] {dba1a51f-c994-421a-9685-1e269d7313a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.680729 [ 1583 ] {99d33252-a6c9-4da5-810c-24ac272aff2f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.682011 [ 1583 ] {99d33252-a6c9-4da5-810c-24ac272aff2f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.732347 [ 1583 ] {ff89dcc0-501c-4ad4-a9a7-1fe269c5755b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.733769 [ 1583 ] {ff89dcc0-501c-4ad4-a9a7-1fe269c5755b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.781701 [ 1583 ] {4b8cf98d-82fe-45ca-8e99-22f38e9bb83c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.782956 [ 1583 ] {4b8cf98d-82fe-45ca-8e99-22f38e9bb83c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.829653 [ 1583 ] {73742533-8fc3-4a3c-ba1d-345d7d4c5bc4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.831657 [ 1583 ] {73742533-8fc3-4a3c-ba1d-345d7d4c5bc4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.885712 [ 1583 ] {d28a1442-25f9-404e-aa36-d5c1a3aece84} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.887528 [ 1583 ] {d28a1442-25f9-404e-aa36-d5c1a3aece84} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.944484 [ 1583 ] {4aa11a11-94a0-4d65-a2a4-004b022dd1c2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.946031 [ 1583 ] {4aa11a11-94a0-4d65-a2a4-004b022dd1c2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.994711 [ 1583 ] {adb3164e-ddd5-4952-9a25-19f611e83ec7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:28.995994 [ 1583 ] {adb3164e-ddd5-4952-9a25-19f611e83ec7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.042556 [ 1583 ] {1e0a2348-b519-43c7-a4fb-01a7b80acd2f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.043886 [ 1583 ] {1e0a2348-b519-43c7-a4fb-01a7b80acd2f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.094127 [ 1583 ] {2f89aaf4-5d27-4af1-8210-2b2c326193d8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.095442 [ 1583 ] {2f89aaf4-5d27-4af1-8210-2b2c326193d8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.143591 [ 1583 ] {25a549e9-757a-4a09-835d-5a429f3509cf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.145020 [ 1583 ] {25a549e9-757a-4a09-835d-5a429f3509cf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.192176 [ 1583 ] {0c7f9f97-e50f-4d7c-aecb-20271837404f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.193449 [ 1583 ] {0c7f9f97-e50f-4d7c-aecb-20271837404f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.236482 [ 1583 ] {9bf702d1-71a2-4b6b-933b-50234ca45eea} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.237703 [ 1583 ] {9bf702d1-71a2-4b6b-933b-50234ca45eea} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.280197 [ 1583 ] {dac9ef50-7be3-4eef-99b5-1bc7f3359844} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.281524 [ 1583 ] {dac9ef50-7be3-4eef-99b5-1bc7f3359844} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.324930 [ 1583 ] {b0963f75-7b0d-4bee-9657-e5d16039635f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.326258 [ 1583 ] {b0963f75-7b0d-4bee-9657-e5d16039635f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.373045 [ 1583 ] {51e78089-a36d-4c94-923d-215b1ded1fbc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.374290 [ 1583 ] {51e78089-a36d-4c94-923d-215b1ded1fbc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.417943 [ 1583 ] {fa9ff325-225c-41fa-a3f3-53e764c40b7f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.419258 [ 1583 ] {fa9ff325-225c-41fa-a3f3-53e764c40b7f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.465475 [ 1583 ] {1f709aed-dad6-47f6-bf8b-2a95cf9e9e69} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.482130 [ 1583 ] {1f709aed-dad6-47f6-bf8b-2a95cf9e9e69} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.530420 [ 1583 ] {35fca132-4ff3-4908-8de4-6057a341dc3a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.531670 [ 1583 ] {35fca132-4ff3-4908-8de4-6057a341dc3a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.586973 [ 1583 ] {fe3080eb-b7dc-442f-8252-14e223eb1160} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.588347 [ 1583 ] {fe3080eb-b7dc-442f-8252-14e223eb1160} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.642713 [ 1583 ] {773d13c4-e60e-4022-a921-d6b1149aafa7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.643924 [ 1583 ] {773d13c4-e60e-4022-a921-d6b1149aafa7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.700847 [ 1583 ] {4d9ae438-fc42-4704-b71f-340b9c85ffaf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.702184 [ 1583 ] {4d9ae438-fc42-4704-b71f-340b9c85ffaf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.747185 [ 1583 ] {b996f4bc-525e-4c02-8d06-03c0cccf8068} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.748723 [ 1583 ] {b996f4bc-525e-4c02-8d06-03c0cccf8068} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.792484 [ 1583 ] {8877b72c-7990-4ea7-9e3f-19875da64faf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.793883 [ 1583 ] {8877b72c-7990-4ea7-9e3f-19875da64faf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.841976 [ 1583 ] {bfbceb9f-8990-4812-874d-34598fe61212} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.843416 [ 1583 ] {bfbceb9f-8990-4812-874d-34598fe61212} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.896681 [ 1583 ] {21400b02-86b5-4ce1-bc2d-eec95e5395a2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.898360 [ 1583 ] {21400b02-86b5-4ce1-bc2d-eec95e5395a2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.948877 [ 1583 ] {ed542355-fbe7-477b-98d1-7f807278f468} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.950442 [ 1583 ] {ed542355-fbe7-477b-98d1-7f807278f468} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.959374 [ 1588 ] {52e67192-7d25-4eb5-88e8-c38344388bf7} executeQuery: Code: 183. DB::Exception: arrayJoin is not allowed in mutations. (UNEXPECTED_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35284) (comment: 02504_disallow_arrayjoin_in_mutations.sql) (in query: ALTER TABLE test_02504 UPDATE b = 33 WHERE arrayJoin([1, 2]) = a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1286: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f95398 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x0000000034f9e7da 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485807c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:29.960348 [ 1588 ] {52e67192-7d25-4eb5-88e8-c38344388bf7} TCPHandler: Code: 183. DB::Exception: arrayJoin is not allowed in mutations. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1286: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f95398 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x0000000034f9e7da 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485807c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.010728 [ 1583 ] {56f34aeb-849d-460c-9d82-067c4a35d7bc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.012636 [ 1583 ] {56f34aeb-849d-460c-9d82-067c4a35d7bc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.065327 [ 1583 ] {a29b10b0-6d2e-4b61-84c4-7d4b9ca4b116} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.066831 [ 1583 ] {a29b10b0-6d2e-4b61-84c4-7d4b9ca4b116} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.119652 [ 1583 ] {4d5ecd02-b675-4ae0-bdf9-15aecf0bdc9e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.121176 [ 1583 ] {4d5ecd02-b675-4ae0-bdf9-15aecf0bdc9e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.173990 [ 1583 ] {16e4323f-503e-4ac1-85ab-ece5e616467d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.175538 [ 1583 ] {16e4323f-503e-4ac1-85ab-ece5e616467d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.230180 [ 1583 ] {8bc34c7e-9209-4b68-9cde-93e7f04f2c18} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.231793 [ 1583 ] {8bc34c7e-9209-4b68-9cde-93e7f04f2c18} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.287458 [ 1583 ] {c3bdba32-e313-45ce-88bf-f0fe50d637ce} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.288849 [ 1583 ] {c3bdba32-e313-45ce-88bf-f0fe50d637ce} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.338605 [ 1583 ] {1dcaab28-9db4-4cbd-bd92-f9391c117e4b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.340079 [ 1583 ] {1dcaab28-9db4-4cbd-bd92-f9391c117e4b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.405748 [ 1583 ] {b92d2177-2b35-406d-aa70-19e99679edb1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.407201 [ 1583 ] {b92d2177-2b35-406d-aa70-19e99679edb1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.458195 [ 1583 ] {5cad68c9-6598-45f8-916a-344c1f209c80} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.459539 [ 1583 ] {5cad68c9-6598-45f8-916a-344c1f209c80} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.508092 [ 1583 ] {37908813-64b8-44a8-8d45-bb65ffb8bd54} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.509881 [ 1583 ] {37908813-64b8-44a8-8d45-bb65ffb8bd54} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.565825 [ 1583 ] {3f671ea9-41d1-4d13-b9a4-fbb00a5df3f1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.567590 [ 1583 ] {3f671ea9-41d1-4d13-b9a4-fbb00a5df3f1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.627590 [ 1583 ] {9d51c6f9-5270-4577-bcb9-70b4d1978de9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.629493 [ 1583 ] {9d51c6f9-5270-4577-bcb9-70b4d1978de9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.686807 [ 1583 ] {4c28689f-acec-4104-9505-5d3735b10db0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.688169 [ 1583 ] {4c28689f-acec-4104-9505-5d3735b10db0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.739972 [ 1583 ] {3f202361-c7e8-4a9e-b215-81b5e65c5fda} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.741551 [ 1583 ] {3f202361-c7e8-4a9e-b215-81b5e65c5fda} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.790688 [ 1583 ] {46d804dc-192a-43dd-9f14-926268bc3f8b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.792227 [ 1583 ] {46d804dc-192a-43dd-9f14-926268bc3f8b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.848432 [ 1583 ] {c947a8d8-7887-4d88-84a3-31d6ba5fa197} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.850326 [ 1583 ] {c947a8d8-7887-4d88-84a3-31d6ba5fa197} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.914205 [ 1583 ] {9a7cd857-95b7-4f96-a9a7-267fb62bd31d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.915748 [ 1583 ] {9a7cd857-95b7-4f96-a9a7-267fb62bd31d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.970415 [ 1583 ] {dd9fe698-b136-4533-8c80-fed2842cdae7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:30.971943 [ 1583 ] {dd9fe698-b136-4533-8c80-fed2842cdae7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.022679 [ 1583 ] {f56ddf96-ff01-4ddd-8df8-ef78d0725703} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.024118 [ 1583 ] {f56ddf96-ff01-4ddd-8df8-ef78d0725703} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.079394 [ 1583 ] {f4464c45-d373-48e0-b550-29dee3654b79} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.081125 [ 1583 ] {f4464c45-d373-48e0-b550-29dee3654b79} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.135524 [ 1583 ] {0aec7bce-7281-42ce-84e2-40fc89ae5d95} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.137172 [ 1583 ] {0aec7bce-7281-42ce-84e2-40fc89ae5d95} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.196083 [ 1583 ] {152137ef-6976-4c31-a4a9-24680ae0fb5c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.197519 [ 1583 ] {152137ef-6976-4c31-a4a9-24680ae0fb5c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.250473 [ 1583 ] {9386df89-4268-42c4-a27a-ec1ee6b937e9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.252087 [ 1583 ] {9386df89-4268-42c4-a27a-ec1ee6b937e9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.304783 [ 1583 ] {da453b90-b78c-49ff-b0d8-76c6c7e32617} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.306154 [ 1583 ] {da453b90-b78c-49ff-b0d8-76c6c7e32617} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.358175 [ 1583 ] {97347fa7-ce46-46f7-ba76-f536b5077071} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.359512 [ 1583 ] {97347fa7-ce46-46f7-ba76-f536b5077071} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.413358 [ 1583 ] {d00b9a75-4179-461a-8458-ab9149a64b49} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.414999 [ 1583 ] {d00b9a75-4179-461a-8458-ab9149a64b49} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.471163 [ 1583 ] {44b0fe9f-1168-4dbe-b444-6212e256d1a0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.472885 [ 1583 ] {44b0fe9f-1168-4dbe-b444-6212e256d1a0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.536001 [ 1583 ] {8a9ae577-9b69-41a2-ae14-e3f4225ebd31} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.537779 [ 1583 ] {8a9ae577-9b69-41a2-ae14-e3f4225ebd31} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.589019 [ 1583 ] {e1c16f0c-f50a-48be-8b4c-da8dc5c5d96d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.590534 [ 1583 ] {e1c16f0c-f50a-48be-8b4c-da8dc5c5d96d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.644861 [ 1583 ] {ba89d684-a57a-424d-8168-b1b76706012a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.646767 [ 1583 ] {ba89d684-a57a-424d-8168-b1b76706012a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.699560 [ 1583 ] {ace57786-885d-49ae-9da2-01cd0760ab53} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.701149 [ 1583 ] {ace57786-885d-49ae-9da2-01cd0760ab53} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.751728 [ 1583 ] {5f118a4e-0dbd-4fc4-9317-bc0213676f6f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.753293 [ 1583 ] {5f118a4e-0dbd-4fc4-9317-bc0213676f6f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.811575 [ 1583 ] {64a04609-c266-4bbd-bef3-b31e8ba86946} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.813022 [ 1583 ] {64a04609-c266-4bbd-bef3-b31e8ba86946} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.862486 [ 1583 ] {ae6908ea-3aa4-454e-85bb-7c858911dcca} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.863852 [ 1583 ] {ae6908ea-3aa4-454e-85bb-7c858911dcca} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.914842 [ 1583 ] {4da27f6f-6731-4ed6-8486-ab1fbbf64510} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.916195 [ 1583 ] {4da27f6f-6731-4ed6-8486-ab1fbbf64510} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.967052 [ 1583 ] {cf2b8724-a0ec-4da8-9f80-1023e7699694} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:31.968519 [ 1583 ] {cf2b8724-a0ec-4da8-9f80-1023e7699694} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.024229 [ 1583 ] {6134acb5-2226-4f6e-8f5e-b755d6fc5be9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.025977 [ 1583 ] {6134acb5-2226-4f6e-8f5e-b755d6fc5be9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.076121 [ 1583 ] {af3602d7-30bc-41bc-b26a-cc0f2ca84683} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.077860 [ 1583 ] {af3602d7-30bc-41bc-b26a-cc0f2ca84683} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.128123 [ 1583 ] {47bf600e-bb98-4e12-84d4-3865b535f74e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.129511 [ 1583 ] {47bf600e-bb98-4e12-84d4-3865b535f74e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.195726 [ 1583 ] {7fff9ac2-16b9-46e3-b4b4-6eae20317f19} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.197295 [ 1583 ] {7fff9ac2-16b9-46e3-b4b4-6eae20317f19} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.261237 [ 1583 ] {85152ec9-32a6-4022-9f50-5a7529ff9a05} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.262887 [ 1583 ] {85152ec9-32a6-4022-9f50-5a7529ff9a05} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.322010 [ 1583 ] {d853b3f6-3e6c-4010-963b-142bcb51d07c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.324037 [ 1583 ] {d853b3f6-3e6c-4010-963b-142bcb51d07c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.378781 [ 1583 ] {2af93e77-4321-4f22-9f09-a7c7c4df32e0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.380563 [ 1583 ] {2af93e77-4321-4f22-9f09-a7c7c4df32e0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.432518 [ 1583 ] {9f84e926-3887-4969-9062-3d6f68d911e5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.433937 [ 1583 ] {9f84e926-3887-4969-9062-3d6f68d911e5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.488551 [ 1583 ] {da850a34-dd4c-46d2-9840-c349b098cdcf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.489979 [ 1583 ] {da850a34-dd4c-46d2-9840-c349b098cdcf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.544204 [ 1583 ] {1ff49103-6b4f-47f6-9c14-7f3cfbc4dc27} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.545643 [ 1583 ] {1ff49103-6b4f-47f6-9c14-7f3cfbc4dc27} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.596207 [ 1583 ] {a02cac9b-7c06-406f-835e-5d53604ec830} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.597754 [ 1583 ] {a02cac9b-7c06-406f-835e-5d53604ec830} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.648559 [ 1583 ] {2ffc9de6-c307-4537-9f5f-fca31b1bce13} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.649926 [ 1583 ] {2ffc9de6-c307-4537-9f5f-fca31b1bce13} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.698154 [ 1583 ] {35a557fa-fbf2-43de-a0bf-b221c5043b12} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.699558 [ 1583 ] {35a557fa-fbf2-43de-a0bf-b221c5043b12} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.750140 [ 1583 ] {f29ba2db-598e-4ca0-b589-a293171b646d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.751558 [ 1583 ] {f29ba2db-598e-4ca0-b589-a293171b646d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.802755 [ 1583 ] {7190264c-1cb7-4301-8afd-ad52acb23618} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.804171 [ 1583 ] {7190264c-1cb7-4301-8afd-ad52acb23618} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.856312 [ 1583 ] {9b1d2c07-5ba9-412b-b62b-4f98053828ec} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.857760 [ 1583 ] {9b1d2c07-5ba9-412b-b62b-4f98053828ec} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.910317 [ 1583 ] {fd3a1ace-6e1f-4772-8fbb-83ef19a63104} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.911663 [ 1583 ] {fd3a1ace-6e1f-4772-8fbb-83ef19a63104} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.964566 [ 1583 ] {364b5fe3-bd9f-4115-b9db-07b5a4d3dc79} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:32.966118 [ 1583 ] {364b5fe3-bd9f-4115-b9db-07b5a4d3dc79} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.018757 [ 1583 ] {8a289537-d9d2-477a-b6ea-7fbad60a215c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.020132 [ 1583 ] {8a289537-d9d2-477a-b6ea-7fbad60a215c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.072275 [ 1583 ] {a1f86397-c220-409e-b3f8-3f7266739ba4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.073803 [ 1583 ] {a1f86397-c220-409e-b3f8-3f7266739ba4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.131598 [ 1583 ] {e3ca1cfd-3731-48f7-8b93-238d447e66da} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.133358 [ 1583 ] {e3ca1cfd-3731-48f7-8b93-238d447e66da} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.191882 [ 1583 ] {ad802efb-79d7-4a28-bece-a6e2d78300cf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.193568 [ 1583 ] {ad802efb-79d7-4a28-bece-a6e2d78300cf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.249287 [ 1583 ] {0af3620f-b9ff-464c-b1e0-b0104f0a066b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.250962 [ 1583 ] {0af3620f-b9ff-464c-b1e0-b0104f0a066b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.304971 [ 1583 ] {65d72d71-e431-4921-b2a3-7455584a9731} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.306418 [ 1583 ] {65d72d71-e431-4921-b2a3-7455584a9731} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.359563 [ 1583 ] {4fc7938f-a9a4-4974-98b3-5145dd15e259} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.361277 [ 1583 ] {4fc7938f-a9a4-4974-98b3-5145dd15e259} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.417215 [ 1583 ] {aefacc85-17c0-47ec-8b8b-11092df4a9c8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.418714 [ 1583 ] {aefacc85-17c0-47ec-8b8b-11092df4a9c8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.471125 [ 1583 ] {ee8d2d51-dcbd-494d-95e6-d139df1b732b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.473023 [ 1583 ] {ee8d2d51-dcbd-494d-95e6-d139df1b732b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.528173 [ 1583 ] {b68f4bdd-33d1-416b-95a1-e1828c76d0f4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.529805 [ 1583 ] {b68f4bdd-33d1-416b-95a1-e1828c76d0f4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.590703 [ 1583 ] {c0092ff1-3a95-4dc6-88f5-c49d1169e353} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.592228 [ 1583 ] {c0092ff1-3a95-4dc6-88f5-c49d1169e353} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.652001 [ 1583 ] {2640e908-8427-40ab-9afa-0e00df87770e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.653479 [ 1583 ] {2640e908-8427-40ab-9afa-0e00df87770e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.709636 [ 1583 ] {bb3a8991-2b45-40db-966d-9e668daead52} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.711072 [ 1583 ] {bb3a8991-2b45-40db-966d-9e668daead52} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.763385 [ 1583 ] {9a13e1d1-e4bb-4048-be23-04531f583340} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.765349 [ 1583 ] {9a13e1d1-e4bb-4048-be23-04531f583340} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.821282 [ 1583 ] {f863b3e3-0191-4f70-9767-fb84d3fd0b4c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.822719 [ 1583 ] {f863b3e3-0191-4f70-9767-fb84d3fd0b4c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.874703 [ 1583 ] {70c582ce-2516-423e-9fa9-bdb06c06322f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.876170 [ 1583 ] {70c582ce-2516-423e-9fa9-bdb06c06322f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.927016 [ 1583 ] {ec6a303c-6fb6-4d72-b560-e5acd68535f9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.928601 [ 1583 ] {ec6a303c-6fb6-4d72-b560-e5acd68535f9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.982336 [ 1583 ] {b038079f-f572-46a1-a8a4-2aa3068a1dcc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:33.983986 [ 1583 ] {b038079f-f572-46a1-a8a4-2aa3068a1dcc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.033558 [ 1583 ] {fc6b88f4-f17d-4556-a76d-4867ca477ce8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.035263 [ 1583 ] {fc6b88f4-f17d-4556-a76d-4867ca477ce8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.092383 [ 1583 ] {0bf6c896-c189-4cd4-bd95-d2788f3562c3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.093916 [ 1583 ] {0bf6c896-c189-4cd4-bd95-d2788f3562c3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.143288 [ 1583 ] {7b185b26-5024-4f59-bf60-89504c846db9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.144693 [ 1583 ] {7b185b26-5024-4f59-bf60-89504c846db9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.197048 [ 1583 ] {7c1de4cd-efc8-427d-acd8-1f8ab61ab0fa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.198793 [ 1583 ] {7c1de4cd-efc8-427d-acd8-1f8ab61ab0fa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.260561 [ 1583 ] {ac0c488e-6436-4676-8ccd-31654120dd4e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.262034 [ 1583 ] {ac0c488e-6436-4676-8ccd-31654120dd4e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.315136 [ 1583 ] {d5d23b08-da96-4b19-a259-d154dfaf2a81} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.316761 [ 1583 ] {d5d23b08-da96-4b19-a259-d154dfaf2a81} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.367094 [ 1583 ] {aa790d4b-fcc2-43e8-b52e-0d40b9da8e11} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.368553 [ 1583 ] {aa790d4b-fcc2-43e8-b52e-0d40b9da8e11} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.417809 [ 1583 ] {a859c18b-789f-4cd4-a766-b0b74cfaa21e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.419183 [ 1583 ] {a859c18b-789f-4cd4-a766-b0b74cfaa21e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.474585 [ 1583 ] {69bbfaf3-ac31-4460-900b-dfa63d7f8d26} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.476193 [ 1583 ] {69bbfaf3-ac31-4460-900b-dfa63d7f8d26} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.527128 [ 1583 ] {f4d49bad-60df-44db-9b0f-8537c1eb9845} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.528989 [ 1583 ] {f4d49bad-60df-44db-9b0f-8537c1eb9845} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.576910 [ 1583 ] {1e811cc1-5073-4c94-9fe7-e10c01148a42} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.578432 [ 1583 ] {1e811cc1-5073-4c94-9fe7-e10c01148a42} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.628074 [ 1583 ] {fc42077f-59b2-488f-af01-bf22a71d2e28} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.629603 [ 1583 ] {fc42077f-59b2-488f-af01-bf22a71d2e28} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.680484 [ 1583 ] {445d19af-2192-4116-b1e4-6e365f9b3030} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.682067 [ 1583 ] {445d19af-2192-4116-b1e4-6e365f9b3030} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.733058 [ 1583 ] {198a3f3d-14be-4df4-b0fb-bb19c1120840} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.734520 [ 1583 ] {198a3f3d-14be-4df4-b0fb-bb19c1120840} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.787768 [ 1583 ] {c92edb52-0823-427a-927d-0dbad0eaa920} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.789431 [ 1583 ] {c92edb52-0823-427a-927d-0dbad0eaa920} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.836449 [ 1583 ] {8f81f691-4223-4134-a042-0fa7ee98c79e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.839127 [ 1583 ] {8f81f691-4223-4134-a042-0fa7ee98c79e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.888692 [ 1583 ] {211cf003-1243-4981-8682-3d39649e217c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.890048 [ 1583 ] {211cf003-1243-4981-8682-3d39649e217c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.939476 [ 1583 ] {98325473-b4c7-4a49-a477-ee6d8866810d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.940820 [ 1583 ] {98325473-b4c7-4a49-a477-ee6d8866810d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.991135 [ 1583 ] {bfd1fccf-8f51-4689-b47b-a19d18179a4a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:34.992517 [ 1583 ] {bfd1fccf-8f51-4689-b47b-a19d18179a4a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.042560 [ 1583 ] {b1012e0b-c76a-4954-95c6-360ef0c59ab5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.044020 [ 1583 ] {b1012e0b-c76a-4954-95c6-360ef0c59ab5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.093534 [ 1583 ] {24a46226-ebc6-48ba-a22d-76069bf2c7fc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.094980 [ 1583 ] {24a46226-ebc6-48ba-a22d-76069bf2c7fc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.144006 [ 1583 ] {1038dec3-6f2a-41f2-8768-5b35b2d8e9c0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.145328 [ 1583 ] {1038dec3-6f2a-41f2-8768-5b35b2d8e9c0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.192634 [ 1583 ] {b2ca0c0b-be97-42a1-9569-4c141f778b5c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.193955 [ 1583 ] {b2ca0c0b-be97-42a1-9569-4c141f778b5c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.239402 [ 1583 ] {469817d2-fd92-46e3-ba38-e638284cc719} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.240676 [ 1583 ] {469817d2-fd92-46e3-ba38-e638284cc719} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.286533 [ 1583 ] {3a163e5a-b39c-4fb3-86d3-5c74f8aa60b9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.288073 [ 1583 ] {3a163e5a-b39c-4fb3-86d3-5c74f8aa60b9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.332407 [ 1583 ] {1c49bbb6-af74-4f98-9de2-afbe26c309fd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.333756 [ 1583 ] {1c49bbb6-af74-4f98-9de2-afbe26c309fd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.383375 [ 1583 ] {2d08aa1f-65ee-47d5-a795-a2d6c5bfeda7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.384899 [ 1583 ] {2d08aa1f-65ee-47d5-a795-a2d6c5bfeda7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.433192 [ 1583 ] {b86635fc-f9e6-40a5-9652-0e1b5d43b003} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.434589 [ 1583 ] {b86635fc-f9e6-40a5-9652-0e1b5d43b003} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.485963 [ 1583 ] {2b997c9f-b000-458d-bc6a-05e57604c823} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.487581 [ 1583 ] {2b997c9f-b000-458d-bc6a-05e57604c823} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.539519 [ 1583 ] {e7f57530-8300-436a-8fb0-d28e0d1b4d7d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.540929 [ 1583 ] {e7f57530-8300-436a-8fb0-d28e0d1b4d7d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.590759 [ 1583 ] {62954c20-4689-49c7-a4a6-636a1ccd0d1a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.592489 [ 1583 ] {62954c20-4689-49c7-a4a6-636a1ccd0d1a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.644324 [ 1583 ] {788657d0-bd4d-4eb0-add5-ce0ea501a373} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.645691 [ 1583 ] {788657d0-bd4d-4eb0-add5-ce0ea501a373} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.695627 [ 1583 ] {b6e53133-6670-4a94-875b-c57d8918387e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.697006 [ 1583 ] {b6e53133-6670-4a94-875b-c57d8918387e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.746268 [ 1583 ] {3e93e887-5026-4e34-b6e2-3aa0c6bee5e8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.747578 [ 1583 ] {3e93e887-5026-4e34-b6e2-3aa0c6bee5e8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.796356 [ 1583 ] {321fa333-262e-4e53-909d-ef7ca4649614} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.797814 [ 1583 ] {321fa333-262e-4e53-909d-ef7ca4649614} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.846144 [ 1583 ] {66695b3f-8544-4ce0-89b0-d0472f01cb6b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.847460 [ 1583 ] {66695b3f-8544-4ce0-89b0-d0472f01cb6b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.907947 [ 1583 ] {cfd87924-cc74-454d-8a13-086332f28e98} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.909832 [ 1583 ] {cfd87924-cc74-454d-8a13-086332f28e98} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.922545 [ 946 ] {} test_brqp5eg8.rmt (a08bae99-a0af-4351-b0cc-74ec32f6d31e): Found 1 empty unexpected parts (probably some dropped parts were not cleaned up before restart): [all_0_1_2] 2025.06.18 11:09:35.958375 [ 1583 ] {8063978f-bd89-4b8b-80ab-aeb12d4367a8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:35.959650 [ 1583 ] {8063978f-bd89-4b8b-80ab-aeb12d4367a8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.009766 [ 1583 ] {e80f8ddd-8811-4ff9-86a2-487fbbc5c6f3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.011743 [ 1583 ] {e80f8ddd-8811-4ff9-86a2-487fbbc5c6f3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.076141 [ 1583 ] {858a7179-4e82-414d-9400-73e930157eba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.078154 [ 1583 ] {858a7179-4e82-414d-9400-73e930157eba} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.129824 [ 1583 ] {c40d9959-c09a-4a1e-9ce1-55d51cfd8ae5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.131296 [ 1583 ] {c40d9959-c09a-4a1e-9ce1-55d51cfd8ae5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.142203 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx62_10131} executeQuery: Code: 232. DB::Exception: No part all_2_2_0 in committed state. (NO_SUCH_DATA_PART) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52276) (in query: alter table drop_part_after_table drop part 'all_2_2_0'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5081: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397c0290 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.143757 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx62_10131} DynamicQueryHandler: Code: 232. DB::Exception: No part all_2_2_0 in committed state. (NO_SUCH_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5081: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397c0290 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:36.179846 [ 1583 ] {cb968fda-472e-4646-aec7-5391bf8d3145} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.181131 [ 1583 ] {cb968fda-472e-4646-aec7-5391bf8d3145} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.189680 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx62_6544} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52280) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000358d31f9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000358d1a93 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.190987 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx62_6544} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000358d31f9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000358d1a93 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:36.226672 [ 1583 ] {5318b30c-8766-41f2-b382-9f1da2802187} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.233343 [ 1583 ] {5318b30c-8766-41f2-b382-9f1da2802187} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.280712 [ 1583 ] {56db5485-e6a0-4dae-8d53-a1072ec21bb6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.281998 [ 1583 ] {56db5485-e6a0-4dae-8d53-a1072ec21bb6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.329691 [ 1583 ] {0e68ebac-121f-4214-a9fb-6352deb7a76a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.331043 [ 1583 ] {0e68ebac-121f-4214-a9fb-6352deb7a76a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.380280 [ 1583 ] {44ed2628-5a9a-4ba6-aec6-da9305332407} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.381818 [ 1583 ] {44ed2628-5a9a-4ba6-aec6-da9305332407} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.431366 [ 1583 ] {a3a8f3a2-ff37-4753-9c3c-c43e86946c13} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.432829 [ 1583 ] {a3a8f3a2-ff37-4753-9c3c-c43e86946c13} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.482918 [ 1583 ] {248e0518-ed71-4e6b-a03d-60dcb9fa10d3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.484421 [ 1583 ] {248e0518-ed71-4e6b-a03d-60dcb9fa10d3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.533545 [ 1583 ] {57289eb7-60cd-40f1-8e22-5745c8c736bd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.534948 [ 1583 ] {57289eb7-60cd-40f1-8e22-5745c8c736bd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.585227 [ 1583 ] {1600faaa-eb7e-4c53-8dcd-d3288e8c158c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.586570 [ 1583 ] {1600faaa-eb7e-4c53-8dcd-d3288e8c158c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.632954 [ 1583 ] {0047c9a2-db69-4d32-a8ce-f53b7bf5b799} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.634315 [ 1583 ] {0047c9a2-db69-4d32-a8ce-f53b7bf5b799} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.680268 [ 1583 ] {72e7cad2-9362-43b9-9932-291af796120c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.681706 [ 1583 ] {72e7cad2-9362-43b9-9932-291af796120c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.733219 [ 1583 ] {7b2a5420-3dde-4bef-9bbe-72ac42a0e3b6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.734645 [ 1583 ] {7b2a5420-3dde-4bef-9bbe-72ac42a0e3b6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.793156 [ 1583 ] {d902103e-0294-4066-911b-83ec6edba650} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.794964 [ 1583 ] {d902103e-0294-4066-911b-83ec6edba650} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.853626 [ 1583 ] {77d48987-1042-4506-af5f-943e99c16832} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.854890 [ 1583 ] {77d48987-1042-4506-af5f-943e99c16832} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.901958 [ 1583 ] {3967ef2e-1bc1-43a4-9b1b-3e7c1ada68f0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.903361 [ 1583 ] {3967ef2e-1bc1-43a4-9b1b-3e7c1ada68f0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.958165 [ 1583 ] {e1e7279b-31a3-4208-9319-d191fa726fa7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:36.959620 [ 1583 ] {e1e7279b-31a3-4208-9319-d191fa726fa7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.013362 [ 1583 ] {897fdada-82e0-478b-95fd-5b6cf2c67511} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.014743 [ 1583 ] {897fdada-82e0-478b-95fd-5b6cf2c67511} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.066314 [ 1583 ] {cc1719fc-fbbc-45c8-84c8-5d737d9650a5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.068011 [ 1583 ] {cc1719fc-fbbc-45c8-84c8-5d737d9650a5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.126745 [ 1583 ] {be5dd4f2-484c-411d-acaa-1da2e481516c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.128532 [ 1583 ] {be5dd4f2-484c-411d-acaa-1da2e481516c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.184659 [ 1583 ] {4c3f3680-39bf-4093-9496-8d0a9cd20cde} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.186324 [ 1583 ] {4c3f3680-39bf-4093-9496-8d0a9cd20cde} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.243576 [ 1583 ] {4ba93c60-1077-4cde-b5ea-d4225e2c0e6d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.245221 [ 1583 ] {4ba93c60-1077-4cde-b5ea-d4225e2c0e6d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.300647 [ 1583 ] {ceac2b77-4f17-42ef-9452-faabaf892f2a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.302480 [ 1583 ] {ceac2b77-4f17-42ef-9452-faabaf892f2a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.363001 [ 1583 ] {68b2b227-6c20-41eb-9aaf-f809a95579bc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.365027 [ 1583 ] {68b2b227-6c20-41eb-9aaf-f809a95579bc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.421243 [ 1583 ] {3cc170d7-ffc3-4594-84da-48d33224c549} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.422766 [ 1583 ] {3cc170d7-ffc3-4594-84da-48d33224c549} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.478795 [ 1583 ] {9f510046-04c7-4ef1-9383-5298b0295e6d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.480701 [ 1583 ] {9f510046-04c7-4ef1-9383-5298b0295e6d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.529660 [ 1583 ] {51be5908-c6ec-4999-b52c-d4c972736af5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.530977 [ 1583 ] {51be5908-c6ec-4999-b52c-d4c972736af5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.577247 [ 1583 ] {ceebe9ca-433a-4247-ba4d-f0acbc163f5a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.578550 [ 1583 ] {ceebe9ca-433a-4247-ba4d-f0acbc163f5a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.633681 [ 1583 ] {64232560-0abb-4d50-a0e2-c4997d5dac64} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.635928 [ 1583 ] {64232560-0abb-4d50-a0e2-c4997d5dac64} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.687976 [ 1583 ] {7b8ef7a6-a6e1-404a-8b6d-5c2babd627e6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.689389 [ 1583 ] {7b8ef7a6-a6e1-404a-8b6d-5c2babd627e6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.743268 [ 1583 ] {a4cc0a6b-5b36-4d7f-b81f-8a9c810fe5df} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.744814 [ 1583 ] {a4cc0a6b-5b36-4d7f-b81f-8a9c810fe5df} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.796339 [ 1583 ] {fb1265fa-51a3-4cc1-9c2f-d504b1aad300} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.797765 [ 1583 ] {fb1265fa-51a3-4cc1-9c2f-d504b1aad300} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.849518 [ 1583 ] {a99f90fa-836c-4011-b55a-ed2d075744ed} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.851174 [ 1583 ] {a99f90fa-836c-4011-b55a-ed2d075744ed} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.900491 [ 1583 ] {cc6886ac-edb8-4bbe-ad8a-a60fd078df20} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.902356 [ 1583 ] {cc6886ac-edb8-4bbe-ad8a-a60fd078df20} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.955206 [ 1583 ] {87cbca74-879e-4ef7-afe4-973f97145d22} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:37.956957 [ 1583 ] {87cbca74-879e-4ef7-afe4-973f97145d22} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.008344 [ 1583 ] {0b3ea5ab-8eab-42ca-a573-11ce1abd82aa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.009925 [ 1583 ] {0b3ea5ab-8eab-42ca-a573-11ce1abd82aa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.058898 [ 1583 ] {bc0ee1e1-c240-445c-bcfb-4733c3eded31} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.060199 [ 1583 ] {bc0ee1e1-c240-445c-bcfb-4733c3eded31} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.139626 [ 1583 ] {c663cbe9-698d-41c4-84cb-8f97c85f1f53} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.141494 [ 1583 ] {c663cbe9-698d-41c4-84cb-8f97c85f1f53} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.191567 [ 1583 ] {a7fcafef-f453-44cc-b2da-56db239fefba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.192959 [ 1583 ] {a7fcafef-f453-44cc-b2da-56db239fefba} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.242421 [ 1583 ] {e8caee23-dd70-45ac-a89c-bb5f0c7fad9f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.243982 [ 1583 ] {e8caee23-dd70-45ac-a89c-bb5f0c7fad9f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.292845 [ 1583 ] {b2a61809-a392-46e8-b01b-f5b31885f8aa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.294281 [ 1583 ] {b2a61809-a392-46e8-b01b-f5b31885f8aa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.343807 [ 1583 ] {877dea69-989e-49a7-8704-fb911ef0a640} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.345187 [ 1583 ] {877dea69-989e-49a7-8704-fb911ef0a640} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.394566 [ 1583 ] {bce934a4-3236-4784-bfb0-1551bf0084cd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.395975 [ 1583 ] {bce934a4-3236-4784-bfb0-1551bf0084cd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.445327 [ 1583 ] {af98087b-fe59-4d1d-afb8-82780a1ca6e5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.446685 [ 1583 ] {af98087b-fe59-4d1d-afb8-82780a1ca6e5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.500933 [ 1583 ] {2bf4af03-3451-4d51-8250-7e089b65ef11} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.503280 [ 1583 ] {2bf4af03-3451-4d51-8250-7e089b65ef11} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.563300 [ 1583 ] {5fdaed37-d5ce-4dd1-9779-c4aebf33d7d5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.564712 [ 1583 ] {5fdaed37-d5ce-4dd1-9779-c4aebf33d7d5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.616335 [ 1583 ] {d6b16e0d-0988-4efa-a6c8-651f22a6bcd1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.617924 [ 1583 ] {d6b16e0d-0988-4efa-a6c8-651f22a6bcd1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.667244 [ 1583 ] {7b5872f6-7c6f-44b0-a0c0-aa084909a466} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.668765 [ 1583 ] {7b5872f6-7c6f-44b0-a0c0-aa084909a466} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.716933 [ 1583 ] {6cd15eae-54c6-4507-9be9-e48fcb65820f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.718390 [ 1583 ] {6cd15eae-54c6-4507-9be9-e48fcb65820f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.767655 [ 1583 ] {732cb731-f4cc-4e0b-af49-b78fce267a49} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.770961 [ 1583 ] {732cb731-f4cc-4e0b-af49-b78fce267a49} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.817833 [ 1583 ] {3fcb0ebe-6b98-4965-a6c4-004c43b73f8c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.819106 [ 1583 ] {3fcb0ebe-6b98-4965-a6c4-004c43b73f8c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.873786 [ 1583 ] {60c9fefd-ff8b-478b-8b74-80aa7a1bb25d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.875526 [ 1583 ] {60c9fefd-ff8b-478b-8b74-80aa7a1bb25d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.925556 [ 1583 ] {1dbdba50-884d-4437-8832-27a9aedd29a1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.927232 [ 1583 ] {1dbdba50-884d-4437-8832-27a9aedd29a1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.976996 [ 1583 ] {0d4935e4-482d-4686-98d5-ad64fe91a93f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:38.978381 [ 1583 ] {0d4935e4-482d-4686-98d5-ad64fe91a93f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.029105 [ 1583 ] {ab8d2d01-549f-44f1-9fe9-95b5cfe2ef37} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.030533 [ 1583 ] {ab8d2d01-549f-44f1-9fe9-95b5cfe2ef37} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.082000 [ 1583 ] {67059c0d-1f9f-4e52-aff5-f83b9868348d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.083506 [ 1583 ] {67059c0d-1f9f-4e52-aff5-f83b9868348d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.129731 [ 1583 ] {04e40d96-ffd9-4b8a-ba4e-d6a224a024c3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.131181 [ 1583 ] {04e40d96-ffd9-4b8a-ba4e-d6a224a024c3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.176563 [ 1583 ] {30ba933a-7c69-4c64-a718-a169a42e52f0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.177896 [ 1583 ] {30ba933a-7c69-4c64-a718-a169a42e52f0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.223556 [ 1583 ] {69558665-4cc9-43da-be2b-fad99b40d23f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.224867 [ 1583 ] {69558665-4cc9-43da-be2b-fad99b40d23f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.267746 [ 1583 ] {ea04c504-1918-49f4-afb6-80b3903e5912} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.269052 [ 1583 ] {ea04c504-1918-49f4-afb6-80b3903e5912} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.313844 [ 1583 ] {4cfcedd6-ce00-4ef2-9e45-08df49b31fa9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.315217 [ 1583 ] {4cfcedd6-ce00-4ef2-9e45-08df49b31fa9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.362914 [ 1583 ] {06f69209-471e-4f75-87f1-ad7a03f4bbfa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.364300 [ 1583 ] {06f69209-471e-4f75-87f1-ad7a03f4bbfa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.412537 [ 1583 ] {c86f452a-ad07-4764-9c61-d8ff1c00866b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.414339 [ 1583 ] {c86f452a-ad07-4764-9c61-d8ff1c00866b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.468552 [ 1583 ] {dde36d12-bfd3-461f-9ff0-d67cf65595ad} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.470014 [ 1583 ] {dde36d12-bfd3-461f-9ff0-d67cf65595ad} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.519162 [ 1583 ] {3185ab1e-5fe9-4054-9b9c-f9432357b005} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.520573 [ 1583 ] {3185ab1e-5fe9-4054-9b9c-f9432357b005} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.569953 [ 1583 ] {d0d2998d-540e-456c-9923-f18e74644cad} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.571447 [ 1583 ] {d0d2998d-540e-456c-9923-f18e74644cad} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.618698 [ 1583 ] {fd3481cb-fa7d-4e97-b553-79db18f1a60e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.620235 [ 1583 ] {fd3481cb-fa7d-4e97-b553-79db18f1a60e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.668109 [ 1583 ] {8e9a6a51-4b72-48ed-ad2c-e4e8c9079bcc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.669521 [ 1583 ] {8e9a6a51-4b72-48ed-ad2c-e4e8c9079bcc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.716695 [ 1583 ] {33ebecac-fd0d-4b10-80af-96e3845c638d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.718076 [ 1583 ] {33ebecac-fd0d-4b10-80af-96e3845c638d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.763576 [ 1583 ] {756b7627-5e08-4ae3-a059-b426fe58b667} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.764953 [ 1583 ] {756b7627-5e08-4ae3-a059-b426fe58b667} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.812570 [ 1583 ] {36343701-16c0-4b91-8fed-d5e60b23556c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.813982 [ 1583 ] {36343701-16c0-4b91-8fed-d5e60b23556c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.863703 [ 1583 ] {a0e7273f-26ab-4af0-ace5-4333e91138a5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.865073 [ 1583 ] {a0e7273f-26ab-4af0-ace5-4333e91138a5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.915923 [ 1583 ] {bedcc9f9-1e90-4d18-ad8e-ec2a9c4ae18a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.917570 [ 1583 ] {bedcc9f9-1e90-4d18-ad8e-ec2a9c4ae18a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.966292 [ 1583 ] {9f48d9cc-1dae-4a9f-8baa-d00b626db28c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:39.967704 [ 1583 ] {9f48d9cc-1dae-4a9f-8baa-d00b626db28c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.014414 [ 1583 ] {ca6b23bb-bc0b-4a22-977a-3bb290f3724e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.015657 [ 1583 ] {ca6b23bb-bc0b-4a22-977a-3bb290f3724e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.064158 [ 1583 ] {8105713b-7870-4f2d-be64-57b3f37b5280} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.065763 [ 1583 ] {8105713b-7870-4f2d-be64-57b3f37b5280} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.117834 [ 1583 ] {fa8d2556-bd0b-426c-9825-ed820febe654} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.120213 [ 1583 ] {fa8d2556-bd0b-426c-9825-ed820febe654} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.182443 [ 1583 ] {27dc5e8d-8d05-401d-a7e0-6a4e9380f3fd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.184287 [ 1583 ] {27dc5e8d-8d05-401d-a7e0-6a4e9380f3fd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.234356 [ 1583 ] {ab258e3e-05e9-45ac-82c1-af064138a6d5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.235761 [ 1583 ] {ab258e3e-05e9-45ac-82c1-af064138a6d5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.288095 [ 1583 ] {67c8845c-6e62-4183-aae5-13ee5b36bdf4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.289512 [ 1583 ] {67c8845c-6e62-4183-aae5-13ee5b36bdf4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.346384 [ 1583 ] {18d03baa-4523-4945-ba60-b2965fa76879} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.347745 [ 1583 ] {18d03baa-4523-4945-ba60-b2965fa76879} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.355875 [ 1587 ] {ae6515c6-e87f-4161-ad1e-74db7a3bb812} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.356833 [ 1587 ] {ae6515c6-e87f-4161-ad1e-74db7a3bb812} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.383111 [ 1587 ] {412d1082-113b-47ea-a818-d3a576af7ec1} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.384231 [ 1587 ] {412d1082-113b-47ea-a818-d3a576af7ec1} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.403422 [ 1583 ] {207dfd30-cbff-4eed-9573-b3da1da803b4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.405657 [ 1583 ] {207dfd30-cbff-4eed-9573-b3da1da803b4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.464337 [ 1583 ] {0b5a3097-03a3-46ca-9d67-57eec3eec962} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.466392 [ 1583 ] {0b5a3097-03a3-46ca-9d67-57eec3eec962} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.516173 [ 1583 ] {4b1c14d2-72a2-4123-9b9f-db5b6dcdebb6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.517873 [ 1583 ] {4b1c14d2-72a2-4123-9b9f-db5b6dcdebb6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.570486 [ 1583 ] {114c3520-148c-4e8f-80f4-ae0c26416044} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.572068 [ 1583 ] {114c3520-148c-4e8f-80f4-ae0c26416044} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.624791 [ 1583 ] {78462366-d5f0-4cc3-9194-059e796b8046} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.626396 [ 1583 ] {78462366-d5f0-4cc3-9194-059e796b8046} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.677184 [ 1583 ] {8279c92e-b032-4e3a-99c1-1aa9eb31f0f6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.678555 [ 1583 ] {8279c92e-b032-4e3a-99c1-1aa9eb31f0f6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.690103 [ 1587 ] {087dfd73-87c7-46c9-9d83-40947a9620d8} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.690934 [ 1587 ] {087dfd73-87c7-46c9-9d83-40947a9620d8} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.712669 [ 1587 ] {a330de7a-e16a-4ddf-9ca0-951da082b674} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.713574 [ 1587 ] {a330de7a-e16a-4ddf-9ca0-951da082b674} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.730777 [ 1583 ] {c265330f-24d2-4131-bdb5-e5d26d2fb5ca} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.732219 [ 1583 ] {c265330f-24d2-4131-bdb5-e5d26d2fb5ca} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.783164 [ 1583 ] {166ce6b4-bb73-4d29-9f80-28d6ba4f5c92} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.784786 [ 1583 ] {166ce6b4-bb73-4d29-9f80-28d6ba4f5c92} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.834998 [ 1583 ] {b572b94d-a5de-40f9-af7b-a3323f6e951d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.836599 [ 1583 ] {b572b94d-a5de-40f9-af7b-a3323f6e951d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.886350 [ 1583 ] {4437c794-d525-4b46-95e5-17dc0043b635} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.887839 [ 1583 ] {4437c794-d525-4b46-95e5-17dc0043b635} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.930453 [ 1583 ] {fafb346a-3b84-45c8-9ade-b756b1562282} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.931750 [ 1583 ] {fafb346a-3b84-45c8-9ade-b756b1562282} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.981590 [ 1583 ] {476a46d0-eb27-416a-83db-a7ebf580512d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.982701 [ 1587 ] {290888a3-12f6-4539-9e1b-dcbcb7d9ed74} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.983239 [ 1583 ] {476a46d0-eb27-416a-83db-a7ebf580512d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:40.983493 [ 1587 ] {290888a3-12f6-4539-9e1b-dcbcb7d9ed74} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.004298 [ 1587 ] {ad089776-8776-418f-b86f-d17beb74b503} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.005078 [ 1587 ] {ad089776-8776-418f-b86f-d17beb74b503} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.030529 [ 1583 ] {68bffa61-9cd2-457f-ba14-88315171fe55} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.031840 [ 1583 ] {68bffa61-9cd2-457f-ba14-88315171fe55} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.077663 [ 1583 ] {6a88029a-d0b1-47ee-8bc3-fb2d9bfaf077} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.078960 [ 1583 ] {6a88029a-d0b1-47ee-8bc3-fb2d9bfaf077} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.126036 [ 1583 ] {7d7b1985-9915-4d7d-bb45-bd2abab61d28} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.127507 [ 1583 ] {7d7b1985-9915-4d7d-bb45-bd2abab61d28} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.177326 [ 1583 ] {8c7a94bc-6417-4165-84fd-d77a0163e875} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.178824 [ 1583 ] {8c7a94bc-6417-4165-84fd-d77a0163e875} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.224706 [ 1583 ] {449c909c-c0ab-4255-aac5-596d57d117fe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.226057 [ 1583 ] {449c909c-c0ab-4255-aac5-596d57d117fe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.273445 [ 1583 ] {71252fb4-d75e-42ca-8917-ece9b87e212c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.274719 [ 1583 ] {71252fb4-d75e-42ca-8917-ece9b87e212c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.276971 [ 1587 ] {75df3aa8-6d0f-45e3-bab7-767f8f2693ec} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.277837 [ 1587 ] {75df3aa8-6d0f-45e3-bab7-767f8f2693ec} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.299287 [ 1587 ] {852dcd14-cb35-4d10-aedb-e77d845dbdc5} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48102) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.300150 [ 1587 ] {852dcd14-cb35-4d10-aedb-e77d845dbdc5} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.320667 [ 1583 ] {efecbb2b-0f81-4f75-85e7-fc6f0c1f90bb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.321965 [ 1583 ] {efecbb2b-0f81-4f75-85e7-fc6f0c1f90bb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.369477 [ 1583 ] {0e8b713f-d5ee-4151-b0e0-45d116fbf1b7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.370934 [ 1583 ] {0e8b713f-d5ee-4151-b0e0-45d116fbf1b7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.416630 [ 1583 ] {321b3323-07b9-42e3-b821-d76ad9c14cc7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.417979 [ 1583 ] {321b3323-07b9-42e3-b821-d76ad9c14cc7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.463825 [ 1583 ] {b0eac51e-2274-462e-97ed-d470e265095b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.465255 [ 1583 ] {b0eac51e-2274-462e-97ed-d470e265095b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.514947 [ 1583 ] {8247eea5-3925-4442-ad8f-3e8f12173355} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.516380 [ 1583 ] {8247eea5-3925-4442-ad8f-3e8f12173355} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.570972 [ 1583 ] {34fd7e81-03ef-427f-98c4-e7f8951bcd90} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.572346 [ 1583 ] {34fd7e81-03ef-427f-98c4-e7f8951bcd90} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.618174 [ 1583 ] {5a8831a5-ba8d-4262-87f4-fdd1dda450fe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.619689 [ 1583 ] {5a8831a5-ba8d-4262-87f4-fdd1dda450fe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.666602 [ 1583 ] {73d4d3bd-79a3-453b-8657-e655a277e839} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.667950 [ 1583 ] {73d4d3bd-79a3-453b-8657-e655a277e839} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.715909 [ 1583 ] {033e83e0-e6cc-403b-a27a-49a6d54401bc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.717353 [ 1583 ] {033e83e0-e6cc-403b-a27a-49a6d54401bc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.764408 [ 1583 ] {28364df5-bd68-4381-801f-e16e1ab2426d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.765802 [ 1583 ] {28364df5-bd68-4381-801f-e16e1ab2426d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.813312 [ 1583 ] {caf7e9f1-52c0-4d13-85f8-8482a6c5bc6e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.814730 [ 1583 ] {caf7e9f1-52c0-4d13-85f8-8482a6c5bc6e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.862646 [ 1583 ] {d000d18a-a49e-48d3-93fd-24ee39c9e60c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.863922 [ 1583 ] {d000d18a-a49e-48d3-93fd-24ee39c9e60c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.908489 [ 1583 ] {5cbed4ae-fb6a-4fbd-824b-238139743baa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.909813 [ 1583 ] {5cbed4ae-fb6a-4fbd-824b-238139743baa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.955232 [ 1583 ] {d68ee215-a31f-4bf0-b104-c36a88cca9a9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:41.956733 [ 1583 ] {d68ee215-a31f-4bf0-b104-c36a88cca9a9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.007492 [ 1583 ] {22b1fe0d-cf01-44d8-89a1-e4447cca3f3a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.009074 [ 1583 ] {22b1fe0d-cf01-44d8-89a1-e4447cca3f3a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.055046 [ 1583 ] {db7a0bad-bf53-4220-b678-7a27f5a90b19} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.056405 [ 1583 ] {db7a0bad-bf53-4220-b678-7a27f5a90b19} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.099609 [ 1583 ] {f64844a7-9438-4e4d-bba5-6fe397a8d029} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.117318 [ 1583 ] {f64844a7-9438-4e4d-bba5-6fe397a8d029} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.162156 [ 1583 ] {88300d24-4d0e-497a-a936-93e25ea09760} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.163506 [ 1583 ] {88300d24-4d0e-497a-a936-93e25ea09760} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.210557 [ 1583 ] {c4077495-ff8d-4a81-9237-57ccb4346d93} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.211998 [ 1583 ] {c4077495-ff8d-4a81-9237-57ccb4346d93} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.260085 [ 1583 ] {8f532d4c-5ad8-4a80-b59a-ca154f3302c5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.261571 [ 1583 ] {8f532d4c-5ad8-4a80-b59a-ca154f3302c5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.307923 [ 1583 ] {b2d8c934-13ed-4992-a9cc-03b8151a1af2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.309377 [ 1583 ] {b2d8c934-13ed-4992-a9cc-03b8151a1af2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.356194 [ 1583 ] {e594aa60-9d03-4893-aa76-17b8c2793347} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.357629 [ 1583 ] {e594aa60-9d03-4893-aa76-17b8c2793347} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.401980 [ 1583 ] {59efc80b-55fd-4821-abc3-0e99bb27d7d8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.403296 [ 1583 ] {59efc80b-55fd-4821-abc3-0e99bb27d7d8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.447326 [ 1583 ] {b1bf005e-63f1-4621-b780-d2bcdf54ded7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.448757 [ 1583 ] {b1bf005e-63f1-4621-b780-d2bcdf54ded7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.491569 [ 1583 ] {07008692-b7cc-4955-9e45-a4f45d5e38d7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.492927 [ 1583 ] {07008692-b7cc-4955-9e45-a4f45d5e38d7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.537004 [ 1583 ] {b212ffef-8b99-41f4-9ec0-a9e0943545a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.538378 [ 1583 ] {b212ffef-8b99-41f4-9ec0-a9e0943545a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.582336 [ 1583 ] {a013661b-44c5-47de-99fc-4b339829096c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.583756 [ 1583 ] {a013661b-44c5-47de-99fc-4b339829096c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.627778 [ 1583 ] {5f1ed8f5-d5f6-4046-977a-ec71a084ac67} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.629171 [ 1583 ] {5f1ed8f5-d5f6-4046-977a-ec71a084ac67} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.676587 [ 1583 ] {bfb55ca6-2672-4041-a2db-0cc7854daf30} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.678095 [ 1583 ] {bfb55ca6-2672-4041-a2db-0cc7854daf30} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.725162 [ 1583 ] {8425266b-e6ac-4483-aeaf-34249544b5b9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.726592 [ 1583 ] {8425266b-e6ac-4483-aeaf-34249544b5b9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.775154 [ 1583 ] {49694481-5ed6-4e82-a6f1-750d427dd3ee} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.776632 [ 1583 ] {49694481-5ed6-4e82-a6f1-750d427dd3ee} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.822472 [ 1583 ] {c7d559f0-a275-4065-9d4d-f637e589c51e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.823929 [ 1583 ] {c7d559f0-a275-4065-9d4d-f637e589c51e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.868158 [ 1583 ] {3aa8e3d4-7be4-4589-8c3f-c1695ca03955} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.869679 [ 1583 ] {3aa8e3d4-7be4-4589-8c3f-c1695ca03955} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.914720 [ 1583 ] {9f80f6c4-d538-4bb5-8e76-23488cda8886} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.916157 [ 1583 ] {9f80f6c4-d538-4bb5-8e76-23488cda8886} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.962117 [ 1583 ] {653892ec-0804-4165-86e8-b60748d52da3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:42.963643 [ 1583 ] {653892ec-0804-4165-86e8-b60748d52da3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.008138 [ 1583 ] {89e9d276-dd51-42a3-9597-d3b06509888c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.009590 [ 1583 ] {89e9d276-dd51-42a3-9597-d3b06509888c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.055720 [ 1583 ] {f91c7a9d-d525-4a37-bb10-517dcbe4fc84} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.057159 [ 1583 ] {f91c7a9d-d525-4a37-bb10-517dcbe4fc84} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.106424 [ 1583 ] {aedbd652-b17c-4e35-98c9-caff59b946af} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.107751 [ 1583 ] {aedbd652-b17c-4e35-98c9-caff59b946af} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.151517 [ 1583 ] {e9def812-b016-4817-bcef-5431b3454ba3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.152833 [ 1583 ] {e9def812-b016-4817-bcef-5431b3454ba3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.195908 [ 1583 ] {5bad67c1-ff93-4c69-b427-145b024992bd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.197358 [ 1583 ] {5bad67c1-ff93-4c69-b427-145b024992bd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.244145 [ 1583 ] {d200a49c-02a1-4cf9-87a9-14dfbcdeb23e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.245630 [ 1583 ] {d200a49c-02a1-4cf9-87a9-14dfbcdeb23e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.292388 [ 1583 ] {4b8205e3-8b04-4c7b-8c1e-21e0bfafdff8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.293769 [ 1583 ] {4b8205e3-8b04-4c7b-8c1e-21e0bfafdff8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.339604 [ 1583 ] {256cbc74-6c32-4034-88c9-dee21d563c46} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.341051 [ 1583 ] {256cbc74-6c32-4034-88c9-dee21d563c46} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.390222 [ 1583 ] {889f383a-ad6c-4f26-b5a4-eed5cc76ac2c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.391773 [ 1583 ] {889f383a-ad6c-4f26-b5a4-eed5cc76ac2c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.438246 [ 1583 ] {158d70b1-d0cb-4a4c-9cad-648e482a2ac0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.439657 [ 1583 ] {158d70b1-d0cb-4a4c-9cad-648e482a2ac0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.485749 [ 1583 ] {ab29f566-9028-4198-9318-ffdc8605871d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.487121 [ 1583 ] {ab29f566-9028-4198-9318-ffdc8605871d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.534016 [ 1583 ] {6d664e56-3394-4c01-8b43-b962a93f6d6d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.535559 [ 1583 ] {6d664e56-3394-4c01-8b43-b962a93f6d6d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.597231 [ 1583 ] {78afd652-8ed9-4dfa-959c-e3e03abdf26a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.600132 [ 1583 ] {78afd652-8ed9-4dfa-959c-e3e03abdf26a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.654445 [ 1583 ] {00003b37-fc57-43e6-926b-4a965d531cfd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.661938 [ 1583 ] {00003b37-fc57-43e6-926b-4a965d531cfd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.718575 [ 1583 ] {942a88b2-0cf2-4d5c-a9b3-aa2fe77eb392} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.720076 [ 1583 ] {942a88b2-0cf2-4d5c-a9b3-aa2fe77eb392} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.765809 [ 1583 ] {86d5d5d8-da4c-4e71-9130-c17e9dd5617f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.767237 [ 1583 ] {86d5d5d8-da4c-4e71-9130-c17e9dd5617f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.814283 [ 1583 ] {ab4584d1-4bfc-4273-8074-f0340d9604e6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.815689 [ 1583 ] {ab4584d1-4bfc-4273-8074-f0340d9604e6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.862309 [ 1583 ] {373821a7-d7f6-4bcd-ae6a-be648b9353c5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.863766 [ 1583 ] {373821a7-d7f6-4bcd-ae6a-be648b9353c5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.910911 [ 1583 ] {0c94fe8c-efbe-4ef7-96ce-569ee0379710} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.912358 [ 1583 ] {0c94fe8c-efbe-4ef7-96ce-569ee0379710} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.958671 [ 1583 ] {0daaed8b-d5b3-4e4f-a9f8-ad16decb15f1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:43.960007 [ 1583 ] {0daaed8b-d5b3-4e4f-a9f8-ad16decb15f1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.005626 [ 1583 ] {5f720a80-80db-461c-97d4-2cb31bc60fe7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.007092 [ 1583 ] {5f720a80-80db-461c-97d4-2cb31bc60fe7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.050685 [ 1583 ] {3dc75df4-f734-405b-a963-f56b47d0169b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.052042 [ 1583 ] {3dc75df4-f734-405b-a963-f56b47d0169b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.098697 [ 1583 ] {7910ea3d-23d0-41c9-a619-6e9d6c4bcb86} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.100077 [ 1583 ] {7910ea3d-23d0-41c9-a619-6e9d6c4bcb86} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.143461 [ 1583 ] {c85eeb8d-c730-40bb-820b-c0d5aee29446} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.144809 [ 1583 ] {c85eeb8d-c730-40bb-820b-c0d5aee29446} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.191575 [ 1583 ] {16ea123e-e0ab-42ca-aa8c-8ea7b8dbc02a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.193020 [ 1583 ] {16ea123e-e0ab-42ca-aa8c-8ea7b8dbc02a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.242159 [ 1583 ] {06a15c1d-e86a-4769-a0d7-a29f88147ae7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.243697 [ 1583 ] {06a15c1d-e86a-4769-a0d7-a29f88147ae7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.287887 [ 1583 ] {db42e8b1-8128-4b3f-9711-8819bdb1b1cf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.289340 [ 1583 ] {db42e8b1-8128-4b3f-9711-8819bdb1b1cf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.334750 [ 1583 ] {dcc3433b-96e8-49f8-8120-33613118b8fe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.336148 [ 1583 ] {dcc3433b-96e8-49f8-8120-33613118b8fe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.380994 [ 1583 ] {3c3ff6ac-f439-4c65-95fe-ddab80504010} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.382352 [ 1583 ] {3c3ff6ac-f439-4c65-95fe-ddab80504010} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.427389 [ 1583 ] {01eb6a61-bab2-4107-b0b6-edd4a3883112} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.428831 [ 1583 ] {01eb6a61-bab2-4107-b0b6-edd4a3883112} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.474451 [ 1583 ] {d674e896-5cbc-4a79-a1e2-71b488d07e22} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.475926 [ 1583 ] {d674e896-5cbc-4a79-a1e2-71b488d07e22} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.521121 [ 1583 ] {6ffc73f9-bf13-4a00-bb62-edaadda3d320} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.522586 [ 1583 ] {6ffc73f9-bf13-4a00-bb62-edaadda3d320} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.567376 [ 1583 ] {58eb6f45-8ec8-40ba-86c2-c0043daff87b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.568735 [ 1583 ] {58eb6f45-8ec8-40ba-86c2-c0043daff87b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.612974 [ 1583 ] {8a05abc7-ddf7-4376-9020-4522dea4c37c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.614300 [ 1583 ] {8a05abc7-ddf7-4376-9020-4522dea4c37c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.660586 [ 1583 ] {ff16ec2d-6fb3-44cc-9fe7-f6b06b69a562} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.661927 [ 1583 ] {ff16ec2d-6fb3-44cc-9fe7-f6b06b69a562} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.706379 [ 1583 ] {3585cc8b-b000-4bcc-9cb7-4f29706c908e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.707741 [ 1583 ] {3585cc8b-b000-4bcc-9cb7-4f29706c908e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.753656 [ 1583 ] {b1d00fdc-acbd-4751-8057-33161499e562} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.754959 [ 1583 ] {b1d00fdc-acbd-4751-8057-33161499e562} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.799122 [ 1583 ] {3f977709-4642-4e13-83e7-b17d75774273} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.800540 [ 1583 ] {3f977709-4642-4e13-83e7-b17d75774273} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.845458 [ 1583 ] {1bb27a87-53f3-45cb-8642-698dd5bf34b4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.846804 [ 1583 ] {1bb27a87-53f3-45cb-8642-698dd5bf34b4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.890384 [ 1583 ] {3b41122f-ae74-4a40-a5c0-2939ba7a2179} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.891869 [ 1583 ] {3b41122f-ae74-4a40-a5c0-2939ba7a2179} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.935735 [ 1583 ] {e9d346ce-f63c-4b82-a541-f13813a43dde} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.937098 [ 1583 ] {e9d346ce-f63c-4b82-a541-f13813a43dde} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.982345 [ 1583 ] {853059d0-8de5-4fd3-a013-cb4a2d8a102b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:44.983688 [ 1583 ] {853059d0-8de5-4fd3-a013-cb4a2d8a102b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.027359 [ 1583 ] {d534b6e5-f935-470c-85da-df6d5aa19675} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.028710 [ 1583 ] {d534b6e5-f935-470c-85da-df6d5aa19675} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.038655 [ 612 ] {0e3ffcba-75cc-43e2-86e8-f6354327fb49} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table = 'test_local_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.039658 [ 612 ] {0e3ffcba-75cc-43e2-86e8-f6354327fb49} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.074918 [ 1583 ] {5909615b-46ce-4ca7-9be2-6cd3edf11cd7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.076333 [ 1583 ] {5909615b-46ce-4ca7-9be2-6cd3edf11cd7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.099826 [ 612 ] {5d2e5872-d3db-4df8-9012-19012039b5fc} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table IN ('test_local_1', 'test_local_2'). (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table in ('test_local_1', 'test_local_2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.103710 [ 612 ] {5d2e5872-d3db-4df8-9012-19012039b5fc} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table IN ('test_local_1', 'test_local_2'). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.127163 [ 1583 ] {04966df1-88d0-4258-a51c-c7cbd6b20b43} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.128590 [ 1583 ] {04966df1-88d0-4258-a51c-c7cbd6b20b43} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.174875 [ 1583 ] {c450912f-d8e2-4852-b442-9e0be5ac486f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.176328 [ 1583 ] {c450912f-d8e2-4852-b442-9e0be5ac486f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.218967 [ 1583 ] {b332d5e7-d149-46dd-8041-cf008190be9e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.220383 [ 1583 ] {b332d5e7-d149-46dd-8041-cf008190be9e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.266138 [ 1583 ] {18604cee-1710-46a4-b90a-bbb15300fd08} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.267583 [ 1583 ] {18604cee-1710-46a4-b90a-bbb15300fd08} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.311391 [ 1583 ] {92aca7c7-40e6-48c7-8b72-212caf772ad6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.312873 [ 1583 ] {92aca7c7-40e6-48c7-8b72-212caf772ad6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.359622 [ 1583 ] {c1701093-0ec0-4e35-bcc7-2f3f9c18d504} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.361075 [ 1583 ] {c1701093-0ec0-4e35-bcc7-2f3f9c18d504} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.407987 [ 1583 ] {e9059e40-ff8b-4ff9-bebe-97cc2287cc7f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.409467 [ 1583 ] {e9059e40-ff8b-4ff9-bebe-97cc2287cc7f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.461176 [ 1583 ] {f5839b7c-c965-48af-8ec4-89618f713d41} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.463061 [ 1583 ] {f5839b7c-c965-48af-8ec4-89618f713d41} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.509801 [ 1583 ] {3a3be03a-1ac5-4780-a2c0-73fc9b6727dc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.511243 [ 1583 ] {3a3be03a-1ac5-4780-a2c0-73fc9b6727dc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.555850 [ 1583 ] {96a8896d-7f47-4093-86af-34f80aa77498} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.557261 [ 1583 ] {96a8896d-7f47-4093-86af-34f80aa77498} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.609260 [ 1583 ] {ad752d31-b65a-4cb7-a110-56e078fef169} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.610679 [ 1583 ] {ad752d31-b65a-4cb7-a110-56e078fef169} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.656314 [ 1583 ] {ffa2271e-c420-4620-9311-79fa4a1b8caf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.657877 [ 1583 ] {ffa2271e-c420-4620-9311-79fa4a1b8caf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.706464 [ 1583 ] {d51ce7aa-ed4d-4355-973c-5c64858d017c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.707852 [ 1583 ] {d51ce7aa-ed4d-4355-973c-5c64858d017c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.751773 [ 1583 ] {96e5ede8-93df-4e08-871e-30ddd12ab95c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.753082 [ 1583 ] {96e5ede8-93df-4e08-871e-30ddd12ab95c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.795229 [ 1583 ] {3cf4d212-e4ef-4112-b5c7-e641041a7ddd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.796574 [ 1583 ] {3cf4d212-e4ef-4112-b5c7-e641041a7ddd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.840914 [ 1583 ] {73a6ea3f-b188-4ea5-8aa2-13a2b7358330} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.842392 [ 1583 ] {73a6ea3f-b188-4ea5-8aa2-13a2b7358330} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.886518 [ 1583 ] {bdb81114-5a59-4587-966f-2997c1fc2c7c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.887942 [ 1583 ] {bdb81114-5a59-4587-966f-2997c1fc2c7c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.905210 [ 612 ] {339ed3b3-4e83-4b1e-9508-42b17fccec82} executeQuery: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table = 'test_distributed_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.906160 [ 612 ] {339ed3b3-4e83-4b1e-9508-42b17fccec82} TCPHandler: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.931613 [ 1583 ] {05a5d581-2220-4e13-bb67-0af322bb2f0f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.932963 [ 1583 ] {05a5d581-2220-4e13-bb67-0af322bb2f0f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.983643 [ 1583 ] {9bdabf6a-5e51-4115-a186-c743ee30dc50} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:45.985049 [ 1583 ] {9bdabf6a-5e51-4115-a186-c743ee30dc50} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.028651 [ 612 ] {c30bd6ca-c84c-4123-b3e7-6c5fce1b355b} executeQuery: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table in ('test_distributed_1', 'test_distributed_2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.029595 [ 612 ] {c30bd6ca-c84c-4123-b3e7-6c5fce1b355b} TCPHandler: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.031160 [ 1583 ] {6057d986-f7f4-4e7d-8048-a85d2e2cc65a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.032672 [ 1583 ] {6057d986-f7f4-4e7d-8048-a85d2e2cc65a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.080337 [ 1583 ] {4b958447-28d4-4b7d-86c6-75eca44f2ff4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.081836 [ 1583 ] {4b958447-28d4-4b7d-86c6-75eca44f2ff4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.127436 [ 1583 ] {e2f3d424-cfbe-4bcb-8f2b-7c669e1825f3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.128819 [ 1583 ] {e2f3d424-cfbe-4bcb-8f2b-7c669e1825f3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.175803 [ 1583 ] {9f45ccb1-3ec6-4b82-b2ab-2b51f7d1fdc4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.177465 [ 1583 ] {9f45ccb1-3ec6-4b82-b2ab-2b51f7d1fdc4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.222809 [ 1583 ] {b60e7b83-9aa8-4d84-8db2-71be7d44f3b7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.224944 [ 1583 ] {b60e7b83-9aa8-4d84-8db2-71be7d44f3b7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.265078 [ 612 ] {d0eedbf5-5fdb-4c95-837b-bcbb76215877} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table = 'test_local_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.266348 [ 612 ] {d0eedbf5-5fdb-4c95-837b-bcbb76215877} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.279004 [ 1583 ] {fef818f2-a3c5-4eea-b75b-1090190d0dc2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.281393 [ 1583 ] {fef818f2-a3c5-4eea-b75b-1090190d0dc2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.344845 [ 1583 ] {79fbe1c8-7786-4e46-a948-d672f83c6917} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.347207 [ 1583 ] {79fbe1c8-7786-4e46-a948-d672f83c6917} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.374043 [ 612 ] {c20a4c57-454a-4aa5-8206-610c8b5771fd} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table IN ('test_local_1', 'test_local_2') ORDER BY value ASC. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table in ('test_local_1', 'test_local_2') ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.374983 [ 612 ] {c20a4c57-454a-4aa5-8206-610c8b5771fd} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table IN ('test_local_1', 'test_local_2') ORDER BY value ASC. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:230: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd4b8 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.399416 [ 1583 ] {9e86497b-c7f6-456d-ba63-b882705ab655} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.401253 [ 1583 ] {9e86497b-c7f6-456d-ba63-b882705ab655} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.445971 [ 1583 ] {489bb9ea-2647-4f54-9252-99abf096877e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.447430 [ 1583 ] {489bb9ea-2647-4f54-9252-99abf096877e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.521282 [ 1583 ] {f0c03c57-b6a0-4083-9d1d-e1c9e68307b1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.522753 [ 1583 ] {f0c03c57-b6a0-4083-9d1d-e1c9e68307b1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.576554 [ 1583 ] {53a4789f-7c27-4846-891d-97617fa5f2b6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.578808 [ 1583 ] {53a4789f-7c27-4846-891d-97617fa5f2b6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.640458 [ 1583 ] {3c66a373-ee89-41b9-88b9-a0eff426d85c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.642242 [ 1583 ] {3c66a373-ee89-41b9-88b9-a0eff426d85c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.697926 [ 1583 ] {b3907ff5-9f3f-448e-839e-d1a62b7d77e7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.699616 [ 1583 ] {b3907ff5-9f3f-448e-839e-d1a62b7d77e7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.752169 [ 1583 ] {1cb70873-9b23-4dd7-8152-ede4164370cf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.753908 [ 1583 ] {1cb70873-9b23-4dd7-8152-ede4164370cf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.804537 [ 1583 ] {665587e6-1147-4789-94eb-3d9bcce1201d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.806395 [ 1583 ] {665587e6-1147-4789-94eb-3d9bcce1201d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.859603 [ 1583 ] {a94155ff-6d8d-494f-8c76-c5f9f1615163} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.861299 [ 1583 ] {a94155ff-6d8d-494f-8c76-c5f9f1615163} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.865160 [ 612 ] {cf9aa0cc-5bb6-40c8-9049-f90b1923677a} executeQuery: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table = 'test_local_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.866201 [ 612 ] {cf9aa0cc-5bb6-40c8-9049-f90b1923677a} TCPHandler: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.906433 [ 1583 ] {8424ce86-763a-4019-99db-e423b6efcf5b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.907830 [ 1583 ] {8424ce86-763a-4019-99db-e423b6efcf5b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.955089 [ 1583 ] {9968e344-746c-4356-a8a8-c917818e3ebf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.956495 [ 1583 ] {9968e344-746c-4356-a8a8-c917818e3ebf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.996138 [ 612 ] {f7d5041d-babc-42d3-a47e-4b715b5c8735} executeQuery: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table in ('test_local_1', 'test_distributed_2') ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:46.997084 [ 612 ] {f7d5041d-babc-42d3-a47e-4b715b5c8735} TCPHandler: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.008128 [ 1583 ] {037c78cb-5fab-4906-9736-93d9f22e2650} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.009739 [ 1583 ] {037c78cb-5fab-4906-9736-93d9f22e2650} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.058532 [ 1583 ] {f95b6af2-e654-489d-9179-5647f3c262ef} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.060090 [ 1583 ] {f95b6af2-e654-489d-9179-5647f3c262ef} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.107867 [ 1583 ] {f0505815-12e4-42bb-95a0-9e5ee7117f43} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.109316 [ 1583 ] {f0505815-12e4-42bb-95a0-9e5ee7117f43} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.154819 [ 1583 ] {9414367a-e972-4644-897f-949b58ca3d3b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.156227 [ 1583 ] {9414367a-e972-4644-897f-949b58ca3d3b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.200857 [ 1583 ] {f91633e5-e90d-4bb8-a173-c52b74448d67} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.202254 [ 1583 ] {f91633e5-e90d-4bb8-a173-c52b74448d67} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.245675 [ 1583 ] {23944165-0484-4418-9080-07f9f7346fa0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.247181 [ 1583 ] {23944165-0484-4418-9080-07f9f7346fa0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.290935 [ 1583 ] {bdb609d6-ef06-4c2d-af90-88a0515f9cbe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.292306 [ 1583 ] {bdb609d6-ef06-4c2d-af90-88a0515f9cbe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.339068 [ 1583 ] {e39a0ea1-2df9-4f5a-ad15-f349503246d0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.340836 [ 1583 ] {e39a0ea1-2df9-4f5a-ad15-f349503246d0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.383306 [ 1583 ] {17f742a8-2d34-4fe6-8a44-813f715fe264} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.384736 [ 1583 ] {17f742a8-2d34-4fe6-8a44-813f715fe264} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.402153 [ 612 ] {d4598d15-2dcd-433f-b084-795ad27d504e} executeQuery: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1|test_distributed_2') PREWHERE _table = 'test_distributed_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.403290 [ 612 ] {d4598d15-2dcd-433f-b084-795ad27d504e} TCPHandler: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.426815 [ 1583 ] {8f34bafc-5fc6-494f-addb-2f158d307800} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.428234 [ 1583 ] {8f34bafc-5fc6-494f-addb-2f158d307800} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.474478 [ 1583 ] {1f7a033a-8d8f-48e1-a586-a3ea8463e542} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.475957 [ 1583 ] {1f7a033a-8d8f-48e1-a586-a3ea8463e542} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.518469 [ 612 ] {2450de71-2f49-47b4-8ce7-b42d2bf30f45} executeQuery: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55570) (comment: 00717_merge_and_distributed.sql) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1|test_distributed_2') PREWHERE _table in ('test_distributed_1', 'test_distributed_2') ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.519240 [ 612 ] {2450de71-2f49-47b4-8ce7-b42d2bf30f45} TCPHandler: Code: 182. DB::Exception: Storage Merge (table _table_function.merge) does not support PREWHERE. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:220: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fd79d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335fccea 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000335f6260 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf6d09 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.522027 [ 1583 ] {33f4ae14-c521-4d6b-ab35-ad13e9465bcb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.523508 [ 1583 ] {33f4ae14-c521-4d6b-ab35-ad13e9465bcb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.574132 [ 1583 ] {f8a03e2f-ad5e-4da3-85f7-7da01b9ab30b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.575930 [ 1583 ] {f8a03e2f-ad5e-4da3-85f7-7da01b9ab30b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.623301 [ 1583 ] {a8c39fc9-529c-4e16-9dc8-b806754a35f7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.624980 [ 1583 ] {a8c39fc9-529c-4e16-9dc8-b806754a35f7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.668860 [ 1583 ] {f0101e1d-396d-44fb-ac23-7346b9875909} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.670240 [ 1583 ] {f0101e1d-396d-44fb-ac23-7346b9875909} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.715041 [ 1583 ] {c1d437fb-b0a4-4192-8954-04175a3dffbf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.716465 [ 1583 ] {c1d437fb-b0a4-4192-8954-04175a3dffbf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.761968 [ 1583 ] {62e8427a-b8ff-464e-b288-b64265938545} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.763390 [ 1583 ] {62e8427a-b8ff-464e-b288-b64265938545} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.808528 [ 1583 ] {2ad589ae-ffa3-4220-9cc5-ce24dc02ccdc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.809998 [ 1583 ] {2ad589ae-ffa3-4220-9cc5-ce24dc02ccdc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.853170 [ 1583 ] {9bf41dad-943c-4523-b387-c3ffb083f8af} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.854590 [ 1583 ] {9bf41dad-943c-4523-b387-c3ffb083f8af} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.898829 [ 1583 ] {81fed50e-887e-4f52-b32a-9e2ea750ccc3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.900297 [ 1583 ] {81fed50e-887e-4f52-b32a-9e2ea750ccc3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.946532 [ 1583 ] {2643845d-7dd4-486f-bcce-56515792aa20} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.948098 [ 1583 ] {2643845d-7dd4-486f-bcce-56515792aa20} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.991815 [ 1583 ] {8401e55f-5fb7-4ed8-802a-d7bebd8a32c2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:47.993183 [ 1583 ] {8401e55f-5fb7-4ed8-802a-d7bebd8a32c2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.036456 [ 1583 ] {413aba12-f0a5-45c5-b91e-e77bf7b7eb8a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.037907 [ 1583 ] {413aba12-f0a5-45c5-b91e-e77bf7b7eb8a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.083033 [ 1583 ] {94d2cdd6-d861-4da2-8f52-95c8b62e870b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.084638 [ 1583 ] {94d2cdd6-d861-4da2-8f52-95c8b62e870b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.133255 [ 1583 ] {bc19d32c-767b-4e4b-877e-30e03ffd8c6d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.134861 [ 1583 ] {bc19d32c-767b-4e4b-877e-30e03ffd8c6d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.180667 [ 1583 ] {a5ee94fb-93b4-4cdc-86c2-aebf71986a52} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.182340 [ 1583 ] {a5ee94fb-93b4-4cdc-86c2-aebf71986a52} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.222121 [ 1583 ] {5f3a3443-c8aa-4840-9755-edc97a534781} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.223733 [ 1583 ] {5f3a3443-c8aa-4840-9755-edc97a534781} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.268985 [ 1583 ] {299944cd-9f39-465c-bf14-af265e20deeb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.270351 [ 1583 ] {299944cd-9f39-465c-bf14-af265e20deeb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.312367 [ 1583 ] {ff8901a2-524f-448d-b7e2-f2e26abfd6b6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.313741 [ 1583 ] {ff8901a2-524f-448d-b7e2-f2e26abfd6b6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.357371 [ 1583 ] {0b5407ae-a035-41c9-beaa-aa44b2cac371} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.358726 [ 1583 ] {0b5407ae-a035-41c9-beaa-aa44b2cac371} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.398466 [ 1583 ] {e98e3e46-51df-4bff-b784-c80a6276ea7b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.399800 [ 1583 ] {e98e3e46-51df-4bff-b784-c80a6276ea7b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.439367 [ 1583 ] {c3057fc3-339f-4686-9d4d-a174e37974c1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.440708 [ 1583 ] {c3057fc3-339f-4686-9d4d-a174e37974c1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.482556 [ 1583 ] {ea41c038-a6ce-4c4a-88f2-0839d1034375} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.483935 [ 1583 ] {ea41c038-a6ce-4c4a-88f2-0839d1034375} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.523306 [ 1583 ] {f04ec2cc-a8c1-4b54-92c4-7f48cdb08118} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.524604 [ 1583 ] {f04ec2cc-a8c1-4b54-92c4-7f48cdb08118} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.567465 [ 1583 ] {c91f4c50-dec6-4511-b50a-d1e6ad98d309} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.568858 [ 1583 ] {c91f4c50-dec6-4511-b50a-d1e6ad98d309} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.606334 [ 1583 ] {2ddd1e9c-2660-4e75-8d51-9be3382efff6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.607643 [ 1583 ] {2ddd1e9c-2660-4e75-8d51-9be3382efff6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.645749 [ 1583 ] {421b77a8-b61a-4f45-ae23-8d05cca0d199} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.647076 [ 1583 ] {421b77a8-b61a-4f45-ae23-8d05cca0d199} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.690639 [ 1583 ] {e50a3989-b533-4923-ad1a-c4a90a288135} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.692168 [ 1583 ] {e50a3989-b533-4923-ad1a-c4a90a288135} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.739084 [ 1583 ] {784c6822-36e7-4427-8f13-f540ee1c2d7a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.740680 [ 1583 ] {784c6822-36e7-4427-8f13-f540ee1c2d7a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.787601 [ 1583 ] {f1f268f2-e810-4b97-9921-04a15384abcc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.789106 [ 1583 ] {f1f268f2-e810-4b97-9921-04a15384abcc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.833451 [ 1583 ] {e3bfc41c-65c9-48ef-9116-8a9443cdd8c4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.834903 [ 1583 ] {e3bfc41c-65c9-48ef-9116-8a9443cdd8c4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.913882 [ 1583 ] {4d6e9568-0cf8-45dc-805b-27f9846ef7d0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.915293 [ 1583 ] {4d6e9568-0cf8-45dc-805b-27f9846ef7d0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.958635 [ 1583 ] {f41c993f-9413-4527-83fd-2102c4f73a2e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:48.960129 [ 1583 ] {f41c993f-9413-4527-83fd-2102c4f73a2e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.005466 [ 1583 ] {37b6d94d-c46b-4b18-aaca-2c5c48854b69} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.007173 [ 1583 ] {37b6d94d-c46b-4b18-aaca-2c5c48854b69} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.053562 [ 1583 ] {643c36fe-4ebb-4b4a-bfaf-3fbdcf039bf6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.054918 [ 1583 ] {643c36fe-4ebb-4b4a-bfaf-3fbdcf039bf6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.096999 [ 1583 ] {93a0987d-593a-4a31-9bec-dd6652160cd2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.098580 [ 1583 ] {93a0987d-593a-4a31-9bec-dd6652160cd2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.140982 [ 1583 ] {9f450cb2-76aa-4d50-aec9-ae9c82bf7617} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.142421 [ 1583 ] {9f450cb2-76aa-4d50-aec9-ae9c82bf7617} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.189623 [ 1583 ] {7a224349-73a1-417e-8d70-af69215e3cc0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.191174 [ 1583 ] {7a224349-73a1-417e-8d70-af69215e3cc0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.237269 [ 1583 ] {48ff04a2-2b78-4fb7-a429-f118e5eea30f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.238701 [ 1583 ] {48ff04a2-2b78-4fb7-a429-f118e5eea30f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.284032 [ 1583 ] {199c0813-ad5b-4118-af93-f2b430ac6a62} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.285579 [ 1583 ] {199c0813-ad5b-4118-af93-f2b430ac6a62} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.332231 [ 1583 ] {b5fc9677-2c0c-4867-8fe1-4074dda50f45} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.333769 [ 1583 ] {b5fc9677-2c0c-4867-8fe1-4074dda50f45} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.375955 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx81_26239} executeQuery: Code: 232. DB::Exception: No part all_2_2_0 in committed state. (NO_SUCH_DATA_PART) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56264) (in query: alter table tt drop part 'all_2_2_0'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5081: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397c0290 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.377206 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx81_26239} DynamicQueryHandler: Code: 232. DB::Exception: No part all_2_2_0 in committed state. (NO_SUCH_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5081: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397c0290 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:49.380821 [ 1583 ] {8977b871-cd31-41d6-8ab3-29727fd711a4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.382344 [ 1583 ] {8977b871-cd31-41d6-8ab3-29727fd711a4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.429546 [ 1583 ] {e87de774-36b3-4141-92a2-ff2a4fca4480} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.431426 [ 1583 ] {e87de774-36b3-4141-92a2-ff2a4fca4480} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.479029 [ 1583 ] {62cc3e91-d107-4b01-bfe3-19bf5fde6a8f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.480472 [ 1583 ] {62cc3e91-d107-4b01-bfe3-19bf5fde6a8f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.523426 [ 1583 ] {aa701c56-3032-4ad9-bc77-f8e2b6553f47} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.524847 [ 1583 ] {aa701c56-3032-4ad9-bc77-f8e2b6553f47} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.571113 [ 1583 ] {be310a83-bf08-408e-8b4b-92a51fd564cf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.572560 [ 1583 ] {be310a83-bf08-408e-8b4b-92a51fd564cf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.634863 [ 1583 ] {c1faed1d-148e-48a4-ad56-f771dfc970e3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.636674 [ 1583 ] {c1faed1d-148e-48a4-ad56-f771dfc970e3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.681091 [ 1583 ] {58d8eb0d-a539-4026-9a66-d58c2087c3aa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.682476 [ 1583 ] {58d8eb0d-a539-4026-9a66-d58c2087c3aa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.726153 [ 1583 ] {fa95b487-791b-4355-9332-24d166d3dabb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.727561 [ 1583 ] {fa95b487-791b-4355-9332-24d166d3dabb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.744764 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx81_26823} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56270) (in query: select count() from tt), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/executeQuery.cpp:914: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac6ae 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.746251 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx81_26823} DynamicQueryHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/executeQuery.cpp:914: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac6ae 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:49.770252 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx81_22798} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56278) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000358d31f9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000358d1a93 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.771509 [ 1534 ] {02421_truncate_isolation_no_merges_test_cu81gxo4_tx81_22798} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000358d31f9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000358d1a93 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:09:49.772354 [ 1583 ] {d8a8b3fc-6dad-4339-97bc-bedef12aa5ac} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.773816 [ 1583 ] {d8a8b3fc-6dad-4339-97bc-bedef12aa5ac} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.816563 [ 1583 ] {9e877701-4f24-4643-b5fd-eed17e5085e7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.818005 [ 1583 ] {9e877701-4f24-4643-b5fd-eed17e5085e7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.862391 [ 1583 ] {a020a657-d5a4-43dc-9e1e-2d798d7011bd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.863868 [ 1583 ] {a020a657-d5a4-43dc-9e1e-2d798d7011bd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.919230 [ 1583 ] {d26a00ff-93d6-4ada-8ab5-3faf7fdc230b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.921022 [ 1583 ] {d26a00ff-93d6-4ada-8ab5-3faf7fdc230b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.971945 [ 1583 ] {203aafba-3269-4bf8-addb-b47a2999c9bc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:49.973902 [ 1583 ] {203aafba-3269-4bf8-addb-b47a2999c9bc} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.026568 [ 1583 ] {11170a24-04ad-4f17-af6f-1d81ede64833} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.028288 [ 1583 ] {11170a24-04ad-4f17-af6f-1d81ede64833} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.073980 [ 1583 ] {ff1f7853-fe68-4eda-ac8d-b3d427f7b3e0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.075368 [ 1583 ] {ff1f7853-fe68-4eda-ac8d-b3d427f7b3e0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.117686 [ 1583 ] {79904e3f-ca19-4178-aaf2-c6569940c763} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.119042 [ 1583 ] {79904e3f-ca19-4178-aaf2-c6569940c763} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.162080 [ 1583 ] {48a9be94-c545-4a43-817b-7d45186038b3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.163686 [ 1583 ] {48a9be94-c545-4a43-817b-7d45186038b3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.210899 [ 1583 ] {ba05a2b4-ac40-4f05-928e-c0f90a0b75d0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.212569 [ 1583 ] {ba05a2b4-ac40-4f05-928e-c0f90a0b75d0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.258269 [ 1583 ] {0cce2599-9900-4608-b993-dc4aac802f5d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.259682 [ 1583 ] {0cce2599-9900-4608-b993-dc4aac802f5d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.298997 [ 1583 ] {b81d3d9e-e8a2-4254-bb14-12bb0125f34e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.300355 [ 1583 ] {b81d3d9e-e8a2-4254-bb14-12bb0125f34e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.339052 [ 1583 ] {cd91e947-503b-4b68-8d72-913e3904cd1a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.340354 [ 1583 ] {cd91e947-503b-4b68-8d72-913e3904cd1a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.379288 [ 1583 ] {67595628-daa2-4224-b47e-a02d5d8c3ba4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.380676 [ 1583 ] {67595628-daa2-4224-b47e-a02d5d8c3ba4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.420561 [ 1583 ] {29e7a7e6-7757-4ee1-94a0-0d8fd609d265} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.421914 [ 1583 ] {29e7a7e6-7757-4ee1-94a0-0d8fd609d265} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.462850 [ 1583 ] {f623c3cc-63a5-42ee-9d3b-f85046e613d2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.464182 [ 1583 ] {f623c3cc-63a5-42ee-9d3b-f85046e613d2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.504709 [ 1583 ] {8700f116-9445-45b3-837f-67c91d412ed6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.506049 [ 1583 ] {8700f116-9445-45b3-837f-67c91d412ed6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.546654 [ 1583 ] {da5789ac-0ce8-49f5-ae39-0d757c88a6a5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.547941 [ 1583 ] {da5789ac-0ce8-49f5-ae39-0d757c88a6a5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.587757 [ 1583 ] {c97a97b1-f209-4d56-98a2-0eb54c353eb7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.589102 [ 1583 ] {c97a97b1-f209-4d56-98a2-0eb54c353eb7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.626069 [ 1583 ] {bcf171d4-04ee-4176-a8a7-bbea91471696} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.627350 [ 1583 ] {bcf171d4-04ee-4176-a8a7-bbea91471696} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.669554 [ 1583 ] {b6907254-c029-4724-a667-7605a92f56b1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.671024 [ 1583 ] {b6907254-c029-4724-a667-7605a92f56b1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.712688 [ 1583 ] {5410cd15-43dc-410a-a95a-859b6325009e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.714024 [ 1583 ] {5410cd15-43dc-410a-a95a-859b6325009e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.755911 [ 1583 ] {7cdb7c1e-ba0a-40ae-865c-e4e8222f4abf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.757530 [ 1583 ] {7cdb7c1e-ba0a-40ae-865c-e4e8222f4abf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.799583 [ 1583 ] {05096427-195e-461d-b1cd-63bccbea93fa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.801014 [ 1583 ] {05096427-195e-461d-b1cd-63bccbea93fa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.843169 [ 1583 ] {a3a7311e-0319-4d8b-89f5-ffcbe9b2e7e6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.844909 [ 1583 ] {a3a7311e-0319-4d8b-89f5-ffcbe9b2e7e6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.891263 [ 1583 ] {901f1879-2fef-4254-ac84-89294a176e4d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.892739 [ 1583 ] {901f1879-2fef-4254-ac84-89294a176e4d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.938330 [ 1583 ] {76be5191-67f9-4506-a209-3f31d3728206} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.939920 [ 1583 ] {76be5191-67f9-4506-a209-3f31d3728206} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.986155 [ 1583 ] {8b57e14d-61f0-4b7a-bdde-d8ad2666be30} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:50.987771 [ 1583 ] {8b57e14d-61f0-4b7a-bdde-d8ad2666be30} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.022438 [ 1587 ] {f558dcd2-36ac-4e6e-8a80-4fd22c2793dd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'period' to function 'seriesDecomposeSTL'. Expected: Unsigned Integer, got: Int8: In scope SELECT seriesDecomposeSTL([2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2], -5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL([2,2,2,2,2,2,2,2,2,2,2,2,2,2], -5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionSeriesDecomposeSTL::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf0ca8e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:09:51.023425 [ 1587 ] {f558dcd2-36ac-4e6e-8a80-4fd22c2793dd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'period' to function 'seriesDecomposeSTL'. Expected: Unsigned Integer, got: Int8: In scope SELECT seriesDecomposeSTL([2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2], -5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionSeriesDecomposeSTL::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf0ca8e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:09:51.032366 [ 1583 ] {d0ad39d1-2d74-4292-ac85-9a0ea57ca37c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.033907 [ 1583 ] {d0ad39d1-2d74-4292-ac85-9a0ea57ca37c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.034709 [ 1587 ] {78ef8407-a1b3-4ead-bea0-af3d564f0511} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'period' to function 'seriesDecomposeSTL'. Expected: Unsigned Integer, got: Float64: In scope SELECT seriesDecomposeSTL([2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2], -5.2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL([2,2,2,2,2,2,2,2,2,2,2,2,2,2], -5.2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionSeriesDecomposeSTL::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf0ca8e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:09:51.035505 [ 1587 ] {78ef8407-a1b3-4ead-bea0-af3d564f0511} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'period' to function 'seriesDecomposeSTL'. Expected: Unsigned Integer, got: Float64: In scope SELECT seriesDecomposeSTL([2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2, 2], -5.2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionSeriesDecomposeSTL::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf0ca8e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:09:51.045426 [ 1587 ] {1c360d79-34e3-4208-8a41-a392e25bcc3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.046310 [ 1587 ] {1c360d79-34e3-4208-8a41-a392e25bcc3e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.056970 [ 1587 ] {9b23fc31-908c-432c-9026-4835fc534b7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL([]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.057770 [ 1587 ] {9b23fc31-908c-432c-9026-4835fc534b7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.075723 [ 1583 ] {7fd2b589-c176-4cc4-bc8c-6343b9f64486} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.077174 [ 1583 ] {7fd2b589-c176-4cc4-bc8c-6343b9f64486} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.120900 [ 1583 ] {c28339a1-3a55-45d8-bb42-9fd79b6b3531} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.122372 [ 1583 ] {c28339a1-3a55-45d8-bb42-9fd79b6b3531} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.169411 [ 1583 ] {c117dde3-282a-4425-872b-f322628e5155} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.171202 [ 1583 ] {c117dde3-282a-4425-872b-f322628e5155} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.225979 [ 1583 ] {44ed2f23-5988-498e-bc7d-320827d00919} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.228588 [ 1583 ] {44ed2f23-5988-498e-bc7d-320827d00919} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.269860 [ 1583 ] {62ad9d30-9a41-433f-8e79-976ba4419a95} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.271265 [ 1583 ] {62ad9d30-9a41-433f-8e79-976ba4419a95} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.315873 [ 1583 ] {a21349c2-83ce-4cef-b2da-a80942638ff0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.317597 [ 1583 ] {a21349c2-83ce-4cef-b2da-a80942638ff0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.362797 [ 1583 ] {a02ecc03-28e1-4ec1-980c-3990852e02d5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.364243 [ 1583 ] {a02ecc03-28e1-4ec1-980c-3990852e02d5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.411559 [ 1583 ] {c4fd9cc7-bd21-4e53-ad17-68110da00eac} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.413113 [ 1583 ] {c4fd9cc7-bd21-4e53-ad17-68110da00eac} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.460574 [ 1583 ] {026999d0-db30-4b4b-a290-f1d35c2bb18b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.462331 [ 1583 ] {026999d0-db30-4b4b-a290-f1d35c2bb18b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.512026 [ 1583 ] {05bc6483-a835-4086-8920-90984ad8d0d8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.513664 [ 1583 ] {05bc6483-a835-4086-8920-90984ad8d0d8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.557247 [ 1583 ] {d45bc93e-f61b-4c57-8fa6-76907b9e9da1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.558886 [ 1583 ] {d45bc93e-f61b-4c57-8fa6-76907b9e9da1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.601177 [ 1583 ] {6983361e-0d51-4bf6-a58a-bd28498b1edb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.602663 [ 1583 ] {6983361e-0d51-4bf6-a58a-bd28498b1edb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.640672 [ 1583 ] {2f534498-f216-489b-b46f-91d7b155a3f8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.641983 [ 1583 ] {2f534498-f216-489b-b46f-91d7b155a3f8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.686606 [ 1583 ] {0b784a8c-1904-4af3-9859-0618ea20c16f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.688227 [ 1583 ] {0b784a8c-1904-4af3-9859-0618ea20c16f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.734687 [ 1583 ] {eef8eb95-d8e4-4541-a960-de50bbf0f720} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.736171 [ 1583 ] {eef8eb95-d8e4-4541-a960-de50bbf0f720} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.783924 [ 1583 ] {d32c2131-eba2-47a2-bd89-b2a58798180f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.785422 [ 1583 ] {d32c2131-eba2-47a2-bd89-b2a58798180f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.828127 [ 1583 ] {fd19754f-c3f9-4a38-b498-e00ab4c69d41} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.829643 [ 1583 ] {fd19754f-c3f9-4a38-b498-e00ab4c69d41} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.835012 [ 1587 ] {ba4852bf-ad49-4d7b-8aaf-d77d6c5baa46} executeQuery: Code: 36. DB::Exception: At least four data points are needed for function seriesDecomposeSTL: In scope SELECT seriesDecomposeSTL([1, 2, 3], 2). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL([1,2,3], 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesDecomposeSTL::executeNumber(DB::IColumn const&, unsigned long, unsigned long, unsigned long, std::vector>&, std::vector>&, std::vector>&) const @ 0x000000001bf0dce2 5. DB::FunctionSeriesDecomposeSTL::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf0a244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:09:51.835997 [ 1587 ] {ba4852bf-ad49-4d7b-8aaf-d77d6c5baa46} TCPHandler: Code: 36. DB::Exception: At least four data points are needed for function seriesDecomposeSTL: In scope SELECT seriesDecomposeSTL([1, 2, 3], 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesDecomposeSTL::executeNumber(DB::IColumn const&, unsigned long, unsigned long, unsigned long, std::vector>&, std::vector>&, std::vector>&) const @ 0x000000001bf0dce2 5. DB::FunctionSeriesDecomposeSTL::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf0a244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:09:51.846144 [ 1587 ] {37f25af9-40bd-4256-aa9c-251abe5f1064} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL([2, 2, 2, 3, 3, 3]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL([2,2,2,3,3,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.847001 [ 1587 ] {37f25af9-40bd-4256-aa9c-251abe5f1064} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL([2, 2, 2, 3, 3, 3]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.874113 [ 1583 ] {ec58ae91-9f89-4e13-a5a8-9f556d45a22c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.876066 [ 1583 ] {ec58ae91-9f89-4e13-a5a8-9f556d45a22c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.922168 [ 1583 ] {dac8d325-91ed-4f77-852a-96e37bf8af1c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.923639 [ 1583 ] {dac8d325-91ed-4f77-852a-96e37bf8af1c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.969567 [ 1583 ] {1875ce5f-a700-4944-a735-d830b6283468} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:51.971417 [ 1583 ] {1875ce5f-a700-4944-a735-d830b6283468} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.018904 [ 1583 ] {82446735-34a0-495b-b380-24179b8e6dd5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.020554 [ 1583 ] {82446735-34a0-495b-b380-24179b8e6dd5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.064363 [ 1583 ] {b2d34add-5b51-4e0e-b93a-d03660e02589} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.065892 [ 1583 ] {b2d34add-5b51-4e0e-b93a-d03660e02589} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.113809 [ 1583 ] {8f2a7350-fb13-4a47-9591-e383df5a62e9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.115333 [ 1583 ] {8f2a7350-fb13-4a47-9591-e383df5a62e9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.157474 [ 1583 ] {f8d06fd5-3129-4fbe-922f-4de40058bf6c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.158984 [ 1583 ] {f8d06fd5-3129-4fbe-922f-4de40058bf6c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.208231 [ 1583 ] {e2bbc825-45ee-40f0-9673-41e77bf988c3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.209639 [ 1583 ] {e2bbc825-45ee-40f0-9673-41e77bf988c3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.249503 [ 1583 ] {af8f9f5d-a6f7-4ebe-bf95-4ee00b094f84} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.251134 [ 1583 ] {af8f9f5d-a6f7-4ebe-bf95-4ee00b094f84} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.301738 [ 1583 ] {52b5f2fa-028a-493d-a2db-ad968ccd0e70} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.303216 [ 1583 ] {52b5f2fa-028a-493d-a2db-ad968ccd0e70} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.349394 [ 1583 ] {1b4c517d-98fd-4c07-9877-ed66d4de6a47} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.350953 [ 1583 ] {1b4c517d-98fd-4c07-9877-ed66d4de6a47} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.401624 [ 1583 ] {cd0a87e6-104f-48ca-a1e8-23d9a70deb1a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.407041 [ 1583 ] {cd0a87e6-104f-48ca-a1e8-23d9a70deb1a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.453735 [ 1583 ] {aee6c784-fd1c-4988-b65a-7d63196621c8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.455351 [ 1583 ] {aee6c784-fd1c-4988-b65a-7d63196621c8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.500388 [ 1583 ] {811bbea4-71d5-4690-8514-38d80c641731} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.502004 [ 1583 ] {811bbea4-71d5-4690-8514-38d80c641731} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.546469 [ 1583 ] {3ee206a2-bb7d-4138-bdce-727440e5caae} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.548185 [ 1583 ] {3ee206a2-bb7d-4138-bdce-727440e5caae} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.595377 [ 1583 ] {5b25573b-01a7-490c-be4e-45af783ba23c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.597172 [ 1583 ] {5b25573b-01a7-490c-be4e-45af783ba23c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.628978 [ 1587 ] {0f529076-cbf4-4a94-909f-67b201c18bfe} executeQuery: Code: 36. DB::Exception: The series should have data of at least two period lengths for function seriesDecomposeSTL: In scope SELECT seriesDecomposeSTL([2, 2, 2, 3, 3, 3], 9272653446478). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL([2,2,2,3,3,3], 9272653446478);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesDecomposeSTL::executeNumber(DB::IColumn const&, unsigned long, unsigned long, unsigned long, std::vector>&, std::vector>&, std::vector>&) const @ 0x000000001bf0dea8 5. DB::FunctionSeriesDecomposeSTL::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf0a244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:09:52.629865 [ 1587 ] {0f529076-cbf4-4a94-909f-67b201c18bfe} TCPHandler: Code: 36. DB::Exception: The series should have data of at least two period lengths for function seriesDecomposeSTL: In scope SELECT seriesDecomposeSTL([2, 2, 2, 3, 3, 3], 9272653446478). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesDecomposeSTL::executeNumber(DB::IColumn const&, unsigned long, unsigned long, unsigned long, std::vector>&, std::vector>&, std::vector>&) const @ 0x000000001bf0dea8 5. DB::FunctionSeriesDecomposeSTL::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf0a244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:09:52.639052 [ 1587 ] {ff63a301-0a9c-45ab-9b8e-557f3d88fec7} executeQuery: Code: 36. DB::Exception: The series should have data of at least two period lengths for function seriesDecomposeSTL: In scope SELECT seriesDecomposeSTL([2, 2, 2, 3, 3, 3], 7). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55922) (comment: 02813_seriesDecomposeSTL.sql) (in query: SELECT seriesDecomposeSTL([2,2,2,3,3,3], 7);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesDecomposeSTL::executeNumber(DB::IColumn const&, unsigned long, unsigned long, unsigned long, std::vector>&, std::vector>&, std::vector>&) const @ 0x000000001bf0dea8 5. DB::FunctionSeriesDecomposeSTL::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf0a244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:09:52.639764 [ 1587 ] {ff63a301-0a9c-45ab-9b8e-557f3d88fec7} TCPHandler: Code: 36. DB::Exception: The series should have data of at least two period lengths for function seriesDecomposeSTL: In scope SELECT seriesDecomposeSTL([2, 2, 2, 3, 3, 3], 7). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesDecomposeSTL::executeNumber(DB::IColumn const&, unsigned long, unsigned long, unsigned long, std::vector>&, std::vector>&, std::vector>&) const @ 0x000000001bf0dea8 5. DB::FunctionSeriesDecomposeSTL::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf0a244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:09:52.641436 [ 1583 ] {42a52dcb-7c79-471e-8d04-02ac3c48958b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.642743 [ 1583 ] {42a52dcb-7c79-471e-8d04-02ac3c48958b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.685331 [ 1583 ] {09adbfef-92ed-4f31-bc6a-31a56ad9511d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.686727 [ 1583 ] {09adbfef-92ed-4f31-bc6a-31a56ad9511d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.725396 [ 1583 ] {d98e9631-bbf0-4141-89f1-c82fcbc20083} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.726722 [ 1583 ] {d98e9631-bbf0-4141-89f1-c82fcbc20083} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.774076 [ 1583 ] {03b0277d-4fd1-4c08-9743-f54d5f1b22a1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.775522 [ 1583 ] {03b0277d-4fd1-4c08-9743-f54d5f1b22a1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.821076 [ 1583 ] {8f5f0dfe-3b94-4c0e-9be4-55227554c82a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.822488 [ 1583 ] {8f5f0dfe-3b94-4c0e-9be4-55227554c82a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.864191 [ 1583 ] {eee7be77-a80c-4beb-9fcc-0da195904166} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.865580 [ 1583 ] {eee7be77-a80c-4beb-9fcc-0da195904166} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.906002 [ 1583 ] {593f5fc5-604f-4513-85bf-a49ac690e872} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.907399 [ 1583 ] {593f5fc5-604f-4513-85bf-a49ac690e872} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.946650 [ 1583 ] {0eaf346b-f4c3-4973-9108-4b967ddbf188} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.948076 [ 1583 ] {0eaf346b-f4c3-4973-9108-4b967ddbf188} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.987895 [ 1583 ] {b1810138-751d-4a94-b612-5a7aa2f0dc33} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:52.989404 [ 1583 ] {b1810138-751d-4a94-b612-5a7aa2f0dc33} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.033599 [ 1583 ] {0c6175ce-e464-430b-9e28-074b9b013a68} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.035007 [ 1583 ] {0c6175ce-e464-430b-9e28-074b9b013a68} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.049822 [ 1814 ] {61f10828-9ea9-464f-a9ad-e8c2355b4a17} executeQuery: Code: 53. DB::Exception: Cannot convert string 'Hello' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56004) (comment: 01686_rocksdb.sql) (in query: SELECT * FROM 01686_test WHERE key = 'Hello';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:09:53.050736 [ 1814 ] {61f10828-9ea9-464f-a9ad-e8c2355b4a17} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'Hello' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:09:53.075435 [ 1583 ] {46e964e4-efab-42f2-b34d-4bbafb59cce1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.076804 [ 1583 ] {46e964e4-efab-42f2-b34d-4bbafb59cce1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.118168 [ 1583 ] {97a7fcde-4332-4ae7-ad69-77b97764c31a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.119739 [ 1583 ] {97a7fcde-4332-4ae7-ad69-77b97764c31a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.181770 [ 1583 ] {918d54d1-08bc-4763-aa4e-ddb7b76e3492} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.183635 [ 1583 ] {918d54d1-08bc-4763-aa4e-ddb7b76e3492} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.232603 [ 1583 ] {d69e55c5-6ce4-4a57-bcdb-7f0315fec412} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.234700 [ 1583 ] {d69e55c5-6ce4-4a57-bcdb-7f0315fec412} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.281793 [ 1583 ] {474031a1-fce3-438f-b81e-bc64533f8e86} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.283603 [ 1583 ] {474031a1-fce3-438f-b81e-bc64533f8e86} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.330686 [ 1583 ] {e28375ea-5083-4105-af24-0335e3b384bf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.332172 [ 1583 ] {e28375ea-5083-4105-af24-0335e3b384bf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.374675 [ 1583 ] {c0393a86-0efb-47ff-986e-2510bbb30d95} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.376091 [ 1583 ] {c0393a86-0efb-47ff-986e-2510bbb30d95} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.425676 [ 1583 ] {2616d946-557a-405c-bfb8-491c121ff2ab} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.427337 [ 1583 ] {2616d946-557a-405c-bfb8-491c121ff2ab} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.473973 [ 1583 ] {1efb380c-0691-4581-a825-f579de2d62b7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.475390 [ 1583 ] {1efb380c-0691-4581-a825-f579de2d62b7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.519950 [ 1583 ] {ed3b61a3-50dc-4649-91f0-d22715f4ed82} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.521365 [ 1583 ] {ed3b61a3-50dc-4649-91f0-d22715f4ed82} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.562541 [ 1583 ] {6c358187-c899-4f5a-a533-b842caff74a3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.563924 [ 1583 ] {6c358187-c899-4f5a-a533-b842caff74a3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.609503 [ 1583 ] {3f0c7c48-e4a3-4205-94e0-d2ae41fb0e17} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.610895 [ 1583 ] {3f0c7c48-e4a3-4205-94e0-d2ae41fb0e17} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.656427 [ 1583 ] {01c7d190-c010-4cc1-8bd5-3d1c4f399c8b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.657988 [ 1583 ] {01c7d190-c010-4cc1-8bd5-3d1c4f399c8b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.703434 [ 1583 ] {f631de8d-8b4d-4ae2-add2-60511f229bb0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.705031 [ 1583 ] {f631de8d-8b4d-4ae2-add2-60511f229bb0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.746608 [ 1583 ] {ace0023f-7dcc-4cb5-8e25-8e43830cd524} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.747966 [ 1583 ] {ace0023f-7dcc-4cb5-8e25-8e43830cd524} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.790117 [ 1583 ] {a93ad477-ecd7-4df8-a67b-168a40bc2a7a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.791663 [ 1583 ] {a93ad477-ecd7-4df8-a67b-168a40bc2a7a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.837121 [ 1583 ] {1012714b-3ff9-4fcb-be72-bc03ef51255b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.838529 [ 1583 ] {1012714b-3ff9-4fcb-be72-bc03ef51255b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.881648 [ 1583 ] {2057ae32-8480-41ab-849d-f8fd34cfcfe5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.883051 [ 1583 ] {2057ae32-8480-41ab-849d-f8fd34cfcfe5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.928222 [ 1583 ] {76d5b918-809a-4212-88e7-2be36125049b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.929827 [ 1583 ] {76d5b918-809a-4212-88e7-2be36125049b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.974744 [ 1583 ] {75e8d9cd-f502-4700-b5ba-d33af1c89f17} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:53.976485 [ 1583 ] {75e8d9cd-f502-4700-b5ba-d33af1c89f17} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.017758 [ 1583 ] {6c98b843-6a37-449b-b564-c128a8e9aa25} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.019260 [ 1583 ] {6c98b843-6a37-449b-b564-c128a8e9aa25} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.063424 [ 1583 ] {1a60d17d-4f0f-40d5-b6c3-94ada81d42b0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.064936 [ 1583 ] {1a60d17d-4f0f-40d5-b6c3-94ada81d42b0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.109131 [ 1583 ] {09fd954a-6ba1-4dfa-ae3b-9807d4c3b0cd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.110606 [ 1583 ] {09fd954a-6ba1-4dfa-ae3b-9807d4c3b0cd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.155112 [ 1583 ] {b450e28e-fe3b-45c8-bc5a-7cccb59bc38a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.156581 [ 1583 ] {b450e28e-fe3b-45c8-bc5a-7cccb59bc38a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.198695 [ 1583 ] {9e342a92-5b18-4105-b43a-f0290edfaa7f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.200089 [ 1583 ] {9e342a92-5b18-4105-b43a-f0290edfaa7f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.244084 [ 1583 ] {62273ea3-7686-4b09-b04a-0f8d0a30ac22} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.245598 [ 1583 ] {62273ea3-7686-4b09-b04a-0f8d0a30ac22} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.282934 [ 1583 ] {c453f8f4-cb1b-4a9f-ba77-ab114fe780f1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.284225 [ 1583 ] {c453f8f4-cb1b-4a9f-ba77-ab114fe780f1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.319293 [ 1583 ] {67678251-2b5c-4683-9c73-3a04b688bd2b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.320641 [ 1583 ] {67678251-2b5c-4683-9c73-3a04b688bd2b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.358724 [ 1583 ] {a4131833-8312-4ccd-8852-61259ebcf6f0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.359990 [ 1583 ] {a4131833-8312-4ccd-8852-61259ebcf6f0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.398324 [ 1583 ] {524e455b-ef59-4586-9648-6803f73c6ce0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.399556 [ 1583 ] {524e455b-ef59-4586-9648-6803f73c6ce0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.431439 [ 1583 ] {0f48fd1e-78b3-48cf-8159-019005ef4633} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.432452 [ 1583 ] {0f48fd1e-78b3-48cf-8159-019005ef4633} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.463521 [ 1583 ] {b202a6f0-0312-4e5d-a309-2b25434b56d7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.464648 [ 1583 ] {b202a6f0-0312-4e5d-a309-2b25434b56d7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.499653 [ 1583 ] {4da6469f-61d6-4654-ad55-272bf2391f76} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.500782 [ 1583 ] {4da6469f-61d6-4654-ad55-272bf2391f76} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.532629 [ 1583 ] {c2dc3811-1459-4f4e-9bf3-7ef3dfeb426a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.533712 [ 1583 ] {c2dc3811-1459-4f4e-9bf3-7ef3dfeb426a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.565630 [ 1583 ] {ee493ddb-2c9f-46cf-8c2c-fe364c798ea8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.566700 [ 1583 ] {ee493ddb-2c9f-46cf-8c2c-fe364c798ea8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.608709 [ 1583 ] {cbca4c92-1505-40d0-9f9e-79a1b352426b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.610237 [ 1583 ] {cbca4c92-1505-40d0-9f9e-79a1b352426b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.653546 [ 1583 ] {9e315cc1-bd40-40f3-a81c-0226ef7cbece} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.654970 [ 1583 ] {9e315cc1-bd40-40f3-a81c-0226ef7cbece} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.695711 [ 1583 ] {61627f97-c33c-42ea-9b8e-3339d168f982} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.697117 [ 1583 ] {61627f97-c33c-42ea-9b8e-3339d168f982} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.736215 [ 1583 ] {4bd35db6-0e8e-4264-854d-6b61ed6fd933} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.737671 [ 1583 ] {4bd35db6-0e8e-4264-854d-6b61ed6fd933} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.740771 [ 612 ] {602eea95-5a1e-4d8a-bbbe-23cfe3b1fcb7} executeQuery: Code: 44. DB::Exception: Illegal column String of first argument of function concatWithSeparator. Must be a constant String. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47674) (comment: 02495_concat_with_separator.sql) (in query: -- negative tests SELECT concatWithSeparator(materialize('|'), 'a', 'b');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::ConcatWithSeparatorImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dd0b94f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.741757 [ 612 ] {602eea95-5a1e-4d8a-bbbe-23cfe3b1fcb7} TCPHandler: Code: 44. DB::Exception: Illegal column String of first argument of function concatWithSeparator. Must be a constant String. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::ConcatWithSeparatorImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dd0b94f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.779875 [ 1583 ] {cf1541f7-e8c1-4a45-ae92-2e914f98fe14} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.781344 [ 1583 ] {cf1541f7-e8c1-4a45-ae92-2e914f98fe14} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.830462 [ 1583 ] {651840d1-5979-46b8-9371-a57d760cd836} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.831876 [ 1583 ] {651840d1-5979-46b8-9371-a57d760cd836} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.875836 [ 1583 ] {6cf39df3-4d35-40bd-b9ed-605e4518104f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.877429 [ 1583 ] {6cf39df3-4d35-40bd-b9ed-605e4518104f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.923313 [ 1583 ] {4491f4e1-cd5a-40fd-8210-a04da85e98a5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.924927 [ 1583 ] {4491f4e1-cd5a-40fd-8210-a04da85e98a5} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.970523 [ 1583 ] {bc5c3c1a-fa00-40ba-864f-c6ca2e7f31ec} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:54.972046 [ 1583 ] {bc5c3c1a-fa00-40ba-864f-c6ca2e7f31ec} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.019801 [ 1583 ] {21bb1078-411b-45f6-a288-072646d6aba4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.021581 [ 1583 ] {21bb1078-411b-45f6-a288-072646d6aba4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.070249 [ 1583 ] {3b3041a8-dd87-48db-a6d6-ab93aafaa145} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.071610 [ 1583 ] {3b3041a8-dd87-48db-a6d6-ab93aafaa145} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.107668 [ 1583 ] {d4751ca3-49a4-4980-908e-465e494bbdf3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.109206 [ 1583 ] {d4751ca3-49a4-4980-908e-465e494bbdf3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.151995 [ 1583 ] {b3852ff8-7e05-4ecf-9bde-91ca9cbbdcba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.153478 [ 1583 ] {b3852ff8-7e05-4ecf-9bde-91ca9cbbdcba} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.196268 [ 1583 ] {2ce861c4-8652-4586-97ca-de9744f76365} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.197893 [ 1583 ] {2ce861c4-8652-4586-97ca-de9744f76365} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.241930 [ 1583 ] {2ab6d448-bcc3-4a90-9b00-912e732d90f1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.252314 [ 1583 ] {2ab6d448-bcc3-4a90-9b00-912e732d90f1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.291030 [ 1583 ] {199579b7-3530-4d24-8d75-4958c4495548} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.292453 [ 1583 ] {199579b7-3530-4d24-8d75-4958c4495548} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.333706 [ 1583 ] {e67a17cb-5753-42b3-bf44-3bab5d2be041} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.335069 [ 1583 ] {e67a17cb-5753-42b3-bf44-3bab5d2be041} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.375925 [ 1583 ] {8af33801-6b2d-4178-bbd2-05aaa21a6e92} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.377430 [ 1583 ] {8af33801-6b2d-4178-bbd2-05aaa21a6e92} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.419815 [ 1583 ] {1e64a40e-497e-4a11-8de2-46b5d8a0f24f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.421244 [ 1583 ] {1e64a40e-497e-4a11-8de2-46b5d8a0f24f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.459956 [ 1583 ] {472b0000-1cb4-4b94-9ff5-18fbda8e69f6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.461465 [ 1583 ] {472b0000-1cb4-4b94-9ff5-18fbda8e69f6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.488760 [ 612 ] {ae4817b6-d6dc-455b-b14e-caeba5b7875e} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47674) (comment: 02495_concat_with_separator.sql) (in query: SELECT concatWithSeparator();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::(anonymous namespace)::ConcatWithSeparatorImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dd0c653 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:09:55.489761 [ 612 ] {ae4817b6-d6dc-455b-b14e-caeba5b7875e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::(anonymous namespace)::ConcatWithSeparatorImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dd0c653 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:09:55.506522 [ 1583 ] {5abc8070-f418-4b69-87c3-e334b456d35b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.508030 [ 1583 ] {5abc8070-f418-4b69-87c3-e334b456d35b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.558268 [ 1583 ] {f5f8b156-9081-4951-8c47-ec510810a636} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.559755 [ 1583 ] {f5f8b156-9081-4951-8c47-ec510810a636} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.604382 [ 1583 ] {42a7e412-a0a6-452c-949e-8eca801a1448} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.605945 [ 1583 ] {42a7e412-a0a6-452c-949e-8eca801a1448} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.652138 [ 1583 ] {81118c7d-614a-450b-9f40-15e22629d1ff} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.653772 [ 1583 ] {81118c7d-614a-450b-9f40-15e22629d1ff} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.702264 [ 1583 ] {37417774-7f61-48c7-b7fa-e0cf318aef87} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.704357 [ 1583 ] {37417774-7f61-48c7-b7fa-e0cf318aef87} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.755345 [ 1583 ] {1b4f1f63-f985-469a-a1d2-b3457a4b7ef6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.757216 [ 1583 ] {1b4f1f63-f985-469a-a1d2-b3457a4b7ef6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.797739 [ 1583 ] {1f1d3b7e-138b-43ab-a9ff-de5dd558f646} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.800304 [ 1583 ] {1f1d3b7e-138b-43ab-a9ff-de5dd558f646} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.843105 [ 1583 ] {416fe0d8-3e49-4601-ac0a-592722505f53} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.845725 [ 1583 ] {416fe0d8-3e49-4601-ac0a-592722505f53} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.884425 [ 1583 ] {3ec87d43-d6b5-40f2-86d1-adbd501dac18} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.886881 [ 1583 ] {3ec87d43-d6b5-40f2-86d1-adbd501dac18} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.934022 [ 1583 ] {c892226d-8517-443d-8713-4f79beb1f00e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.936916 [ 1583 ] {c892226d-8517-443d-8713-4f79beb1f00e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.994766 [ 1583 ] {591abbe0-9447-43ff-98d8-7baaf7fc949c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:55.998304 [ 1583 ] {591abbe0-9447-43ff-98d8-7baaf7fc949c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.069302 [ 1583 ] {6005bf98-bc43-40bf-8f82-d155abe9bba4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.072261 [ 1583 ] {6005bf98-bc43-40bf-8f82-d155abe9bba4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.118229 [ 1583 ] {16002c6d-0740-4ba6-9083-643b70411f42} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.121001 [ 1583 ] {16002c6d-0740-4ba6-9083-643b70411f42} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.165523 [ 1583 ] {7689becb-dfe4-468e-aa9a-38e3f1166c80} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.168468 [ 1583 ] {7689becb-dfe4-468e-aa9a-38e3f1166c80} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.213586 [ 1583 ] {a6cc884c-e670-4263-a256-e8bc5f9dec44} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.216825 [ 1583 ] {a6cc884c-e670-4263-a256-e8bc5f9dec44} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.271925 [ 1583 ] {1f9a1825-4752-42c2-a4f6-35ff198f2428} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.275039 [ 1583 ] {1f9a1825-4752-42c2-a4f6-35ff198f2428} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.363412 [ 1583 ] {102385f8-3f9a-4b42-bea2-7df29cd03117} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.367112 [ 1583 ] {102385f8-3f9a-4b42-bea2-7df29cd03117} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.415032 [ 1583 ] {dcd9f191-cad5-465d-81bf-7fe68e1eb643} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.417803 [ 1583 ] {dcd9f191-cad5-465d-81bf-7fe68e1eb643} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.470274 [ 1583 ] {938aa5f0-983c-4410-9b5f-30ab5beb9dc1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.472606 [ 1583 ] {938aa5f0-983c-4410-9b5f-30ab5beb9dc1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.531900 [ 1583 ] {e3f918a7-c1db-4eb5-9417-3d8ae70c1356} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.534325 [ 1583 ] {e3f918a7-c1db-4eb5-9417-3d8ae70c1356} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.580626 [ 1583 ] {cc72ee43-d7f9-4d26-a312-08ddfa4f6291} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.582173 [ 1583 ] {cc72ee43-d7f9-4d26-a312-08ddfa4f6291} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.624883 [ 1583 ] {86613149-6591-42a2-985c-746a718a3289} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.626453 [ 1583 ] {86613149-6591-42a2-985c-746a718a3289} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.672755 [ 1583 ] {67a7176d-7f8c-4e81-bb0c-883272b5cbb8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.674756 [ 1583 ] {67a7176d-7f8c-4e81-bb0c-883272b5cbb8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.740688 [ 1583 ] {b3c305d7-8ab2-4252-9264-b57555d6c183} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.742380 [ 1583 ] {b3c305d7-8ab2-4252-9264-b57555d6c183} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.784572 [ 1583 ] {1c27ee17-81c9-487e-b072-912437e66fdd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.786428 [ 1583 ] {1c27ee17-81c9-487e-b072-912437e66fdd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.834412 [ 1583 ] {64e1d279-54b7-40fa-b5d5-d80d8298bc01} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.835930 [ 1583 ] {64e1d279-54b7-40fa-b5d5-d80d8298bc01} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.877170 [ 1583 ] {fb97d840-e7e9-43b9-8e6e-c45cfa922a97} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.878667 [ 1583 ] {fb97d840-e7e9-43b9-8e6e-c45cfa922a97} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.921440 [ 1583 ] {7df5de1b-6754-4225-a5c2-552e9504d91e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.923050 [ 1583 ] {7df5de1b-6754-4225-a5c2-552e9504d91e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.970789 [ 1583 ] {240976ea-2c72-451f-bd5b-2913f0e1301a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:56.972422 [ 1583 ] {240976ea-2c72-451f-bd5b-2913f0e1301a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.020172 [ 1583 ] {e923edce-edf1-49e5-b846-600cd78a7dce} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.021946 [ 1583 ] {e923edce-edf1-49e5-b846-600cd78a7dce} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.078250 [ 1583 ] {baac377a-2577-4049-bdbb-013a9cd5e090} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.080355 [ 1583 ] {baac377a-2577-4049-bdbb-013a9cd5e090} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.136592 [ 1583 ] {d973b2cc-b8fc-4455-af8f-6ea44db068fd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.140353 [ 1583 ] {d973b2cc-b8fc-4455-af8f-6ea44db068fd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.193440 [ 1583 ] {2ad062bd-4f4b-4aee-b2a0-ca2a79e3d938} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.196120 [ 1583 ] {2ad062bd-4f4b-4aee-b2a0-ca2a79e3d938} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.241630 [ 1583 ] {274b7632-e765-47fb-9fa6-cb70ba6c90fe} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.244705 [ 1583 ] {274b7632-e765-47fb-9fa6-cb70ba6c90fe} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.289627 [ 1583 ] {3804ddcd-a48c-4e48-8816-46eeeaf5681e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.328815 [ 1583 ] {3804ddcd-a48c-4e48-8816-46eeeaf5681e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.380410 [ 1583 ] {b89efa48-62b7-40bc-a98d-1ea22c89deda} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.386489 [ 1583 ] {b89efa48-62b7-40bc-a98d-1ea22c89deda} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.440230 [ 1583 ] {0eb36bdb-830d-4862-90a3-da9f6537cce6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.442366 [ 1583 ] {0eb36bdb-830d-4862-90a3-da9f6537cce6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.487407 [ 1583 ] {519beaee-dba2-49b6-87aa-0636711e7b3d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.489195 [ 1583 ] {519beaee-dba2-49b6-87aa-0636711e7b3d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.539880 [ 1583 ] {455d653b-670d-4f5e-8e8e-b0e74ae463e3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.541930 [ 1583 ] {455d653b-670d-4f5e-8e8e-b0e74ae463e3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.589237 [ 1583 ] {a4904131-de8d-49e4-aa62-9694d1a41213} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.591218 [ 1583 ] {a4904131-de8d-49e4-aa62-9694d1a41213} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.641378 [ 1583 ] {eaacfce1-75bb-47f9-a322-0da96015231e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.643154 [ 1583 ] {eaacfce1-75bb-47f9-a322-0da96015231e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.693888 [ 1583 ] {bd17d344-4e9e-4345-afbe-f8c8c65c5f31} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.695781 [ 1583 ] {bd17d344-4e9e-4345-afbe-f8c8c65c5f31} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.740370 [ 1583 ] {fe3a8d91-799b-4c08-a7e6-7bc7160fdb5b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.742080 [ 1583 ] {fe3a8d91-799b-4c08-a7e6-7bc7160fdb5b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.787184 [ 1583 ] {4e5668a7-72cc-41a2-a7a9-594b9b141b0e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.788773 [ 1583 ] {4e5668a7-72cc-41a2-a7a9-594b9b141b0e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.833653 [ 1583 ] {cce8c59f-d93c-4a71-9ba7-b85345c41160} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.835263 [ 1583 ] {cce8c59f-d93c-4a71-9ba7-b85345c41160} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.880250 [ 1583 ] {af0bd009-9c5e-4dc7-a7b0-251539e5ac82} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.881872 [ 1583 ] {af0bd009-9c5e-4dc7-a7b0-251539e5ac82} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.931885 [ 1583 ] {bb38de3c-7ce3-49c1-896e-524606fc5b41} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.933736 [ 1583 ] {bb38de3c-7ce3-49c1-896e-524606fc5b41} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.976152 [ 1583 ] {a51ba291-1f19-44e2-a3ee-5c2570185d39} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:57.977693 [ 1583 ] {a51ba291-1f19-44e2-a3ee-5c2570185d39} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.019375 [ 1583 ] {5835d2b3-4765-4975-bfd0-f056b976ddce} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.020846 [ 1583 ] {5835d2b3-4765-4975-bfd0-f056b976ddce} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.062083 [ 1583 ] {185e6148-f4ba-4592-85f7-32cf76698568} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.063529 [ 1583 ] {185e6148-f4ba-4592-85f7-32cf76698568} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.107200 [ 1583 ] {127f89d1-60ce-4466-9bb9-886f268c2264} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.108780 [ 1583 ] {127f89d1-60ce-4466-9bb9-886f268c2264} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.150031 [ 1583 ] {528c1ae6-8f9c-4849-a68c-4eabe7252e12} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.151485 [ 1583 ] {528c1ae6-8f9c-4849-a68c-4eabe7252e12} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.191040 [ 1583 ] {219281d7-7098-4975-87d4-c78052b5bb73} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.192466 [ 1583 ] {219281d7-7098-4975-87d4-c78052b5bb73} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.242587 [ 1583 ] {197a9347-5537-49e0-b145-facadf6fee78} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.244114 [ 1583 ] {197a9347-5537-49e0-b145-facadf6fee78} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.292523 [ 1583 ] {64952607-21ec-4775-85b8-841e85089f89} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.294262 [ 1583 ] {64952607-21ec-4775-85b8-841e85089f89} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.349261 [ 1583 ] {ac0cc700-f35b-44a1-9087-e51990050e16} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.351631 [ 1583 ] {ac0cc700-f35b-44a1-9087-e51990050e16} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.399781 [ 1583 ] {e0082ef2-a33f-413a-883b-3369c507bdd3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.401895 [ 1583 ] {e0082ef2-a33f-413a-883b-3369c507bdd3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.449126 [ 1583 ] {10179bbe-c59e-41a8-b9e0-b6ba99d5b694} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.451051 [ 1583 ] {10179bbe-c59e-41a8-b9e0-b6ba99d5b694} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.499472 [ 1583 ] {c31965b1-fbd9-45b8-9da6-7a19fcea0a01} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.501150 [ 1583 ] {c31965b1-fbd9-45b8-9da6-7a19fcea0a01} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.558271 [ 1583 ] {cfa7c485-ee0b-4ae6-a5e8-421768a9231e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.560178 [ 1583 ] {cfa7c485-ee0b-4ae6-a5e8-421768a9231e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.607457 [ 1583 ] {b0ef38d9-6c2d-4bca-8e75-368a8478a2a9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.608940 [ 1583 ] {b0ef38d9-6c2d-4bca-8e75-368a8478a2a9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.657190 [ 1583 ] {79ade155-74ac-4443-88fc-149b4989483d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.658955 [ 1583 ] {79ade155-74ac-4443-88fc-149b4989483d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.706201 [ 1583 ] {9957669e-6a47-4e34-8aa2-d1a43e1b7307} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.708084 [ 1583 ] {9957669e-6a47-4e34-8aa2-d1a43e1b7307} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.759968 [ 1583 ] {85abca45-ce38-41d7-944c-6b1e86cb7b4e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.761846 [ 1583 ] {85abca45-ce38-41d7-944c-6b1e86cb7b4e} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.817570 [ 1583 ] {242d760b-a4af-44d1-992c-071ff2f21331} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.819388 [ 1583 ] {242d760b-a4af-44d1-992c-071ff2f21331} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.867548 [ 1583 ] {f9e16d6a-7f9e-49d6-a534-68b4a10e85c2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.869554 [ 1583 ] {f9e16d6a-7f9e-49d6-a534-68b4a10e85c2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.925771 [ 1583 ] {9ccd04ea-db28-4247-8f77-e21f8684bcf6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:58.927555 [ 1583 ] {9ccd04ea-db28-4247-8f77-e21f8684bcf6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.001237 [ 1583 ] {b4e7b9c6-6c94-4182-b5dc-ec0260e4f936} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.003973 [ 1583 ] {b4e7b9c6-6c94-4182-b5dc-ec0260e4f936} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.062639 [ 1583 ] {e78757f9-2993-44b5-b2ef-39599e0da023} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.064161 [ 1583 ] {e78757f9-2993-44b5-b2ef-39599e0da023} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.111603 [ 1583 ] {e0aa5764-9169-48c0-ae7b-2b96d3883387} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.113476 [ 1583 ] {e0aa5764-9169-48c0-ae7b-2b96d3883387} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.162373 [ 1583 ] {6afca34b-e997-42c2-b0f8-fb990bbcd56c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.164259 [ 1583 ] {6afca34b-e997-42c2-b0f8-fb990bbcd56c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.214125 [ 1583 ] {2ccec6c4-f801-4203-a2e8-0f9892642dd3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.215863 [ 1583 ] {2ccec6c4-f801-4203-a2e8-0f9892642dd3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.260128 [ 1583 ] {4e46af3c-9fa4-4f2a-b95a-7df7e62bf740} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.261881 [ 1583 ] {4e46af3c-9fa4-4f2a-b95a-7df7e62bf740} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.307479 [ 1583 ] {f401dcbc-a267-464e-8ba4-e4f162d3e870} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.309421 [ 1583 ] {f401dcbc-a267-464e-8ba4-e4f162d3e870} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.358302 [ 1583 ] {f152d9b2-14e9-4ea4-914b-7d892d6919cd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51192) (comment: 03212_thousand_exceptions.sh) (in query: SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:09:59.360023 [ 1583 ] {f152d9b2-14e9-4ea4-914b-7d892d6919cd} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.290225 [ 7729 ] {096ae96b-886a-470f-9a1c-1da3f6e2c69b} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.291356 [ 7729 ] {096ae96b-886a-470f-9a1c-1da3f6e2c69b} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.332848 [ 7729 ] {1ca495e4-554c-49db-bd7c-1d0fc17bdd5c} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.334024 [ 7729 ] {1ca495e4-554c-49db-bd7c-1d0fc17bdd5c} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.371949 [ 7729 ] {ad74a738-3a4b-46b1-b77a-7288fd81bb93} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.372983 [ 7729 ] {ad74a738-3a4b-46b1-b77a-7288fd81bb93} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.410252 [ 7729 ] {805c5489-a5a0-4da2-9a02-df52b00faf49} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:07.411383 [ 7729 ] {805c5489-a5a0-4da2-9a02-df52b00faf49} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:08.672687 [ 1587 ] {6863b002-c487-44af-bbc4-eae83b81a7f8} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35496) (comment: 02426_pod_array_overflow_2.sql) (in query: SELECT * FROM format(Native, 'k0\x23Array(Tuple(FixedString(1), Int64))\0\0\0\0\0\0\0�����\0����������������\0�\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0d\0\0\0\0\0\0\0\0\0\0\0\0\0�1?Vi�%');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad987e3 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fec124c 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:08.673976 [ 1587 ] {6863b002-c487-44af-bbc4-eae83b81a7f8} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad987e3 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fec124c 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.149479 [ 7729 ] {7867dfc4-0527-4419-92fc-f6e080270b75} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.150607 [ 7729 ] {7867dfc4-0527-4419-92fc-f6e080270b75} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.172826 [ 1587 ] {d91f5660-e4e9-4ceb-9cd8-435b2a8a3eca} StorageBuffer (test_oo3n8pz5.buffer_00753): Destination table test_oo3n8pz5.dst_00753 have different type of column y (String != UInt64). Block of data is converted. 2025.06.18 11:10:10.173627 [ 1587 ] {d91f5660-e4e9-4ceb-9cd8-435b2a8a3eca} StorageBuffer (test_oo3n8pz5.buffer_00753): Not all columns from block in buffer exist in destination table test_oo3n8pz5.dst_00753. Some columns are discarded. 2025.06.18 11:10:10.184669 [ 7729 ] {1861a41f-97e9-4c72-a32f-bd2037f7e525} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.185627 [ 7729 ] {1861a41f-97e9-4c72-a32f-bd2037f7e525} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.217264 [ 7729 ] {deede109-a952-432b-ba18-6d656db2027c} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.218278 [ 7729 ] {deede109-a952-432b-ba18-6d656db2027c} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.254838 [ 7729 ] {c5c1e0f6-4272-4ab8-ba60-9fa3ea863796} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.255867 [ 7729 ] {c5c1e0f6-4272-4ab8-ba60-9fa3ea863796} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:10.284027 [ 1587 ] {8989a1ee-8289-48cc-878e-6b33942e6451} StorageBuffer (test_oo3n8pz5.buffer_00753): Destination table test_oo3n8pz5.dst_00753 doesn't have column x. The default values are used. 2025.06.18 11:10:10.284362 [ 1587 ] {8989a1ee-8289-48cc-878e-6b33942e6451} StorageBuffer (test_oo3n8pz5.buffer_00753): Destination table test_oo3n8pz5.dst_00753 has different type of column y (String != UInt64). Data from destination table are converted. 2025.06.18 11:10:10.316467 [ 1587 ] {8af8483a-e4de-4005-8481-6fde40b7b57c} StorageBuffer (test_oo3n8pz5.buffer_00753): Destination table test_oo3n8pz5.dst_00753 have different type of column y (String != UInt64). Block of data is converted. 2025.06.18 11:10:10.317243 [ 1587 ] {8af8483a-e4de-4005-8481-6fde40b7b57c} StorageBuffer (test_oo3n8pz5.buffer_00753): Not all columns from block in buffer exist in destination table test_oo3n8pz5.dst_00753. Some columns are discarded. 2025.06.18 11:10:10.443123 [ 1587 ] {85135280-31d8-401a-96c7-a05efa221e85} StorageBuffer (test_oo3n8pz5.buffer_00753): Destination table test_oo3n8pz5.dst_00753 doesn't have column x. The default values are used. 2025.06.18 11:10:10.443265 [ 1587 ] {85135280-31d8-401a-96c7-a05efa221e85} StorageBuffer (test_oo3n8pz5.buffer_00753): Destination table test_oo3n8pz5.dst_00753 has different type of column y (String != UInt64). Data from destination table are converted. 2025.06.18 11:10:13.083744 [ 7729 ] {864726b6-adc4-41b1-b4df-3d732c68cc9b} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.085086 [ 7729 ] {864726b6-adc4-41b1-b4df-3d732c68cc9b} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.122783 [ 7729 ] {9f6aa9fc-6f49-4b1b-9b8f-b9b106154c94} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.124020 [ 7729 ] {9f6aa9fc-6f49-4b1b-9b8f-b9b106154c94} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.162159 [ 7729 ] {dacdcc6f-24c6-4c4a-ad29-00cffd59832d} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.163535 [ 7729 ] {dacdcc6f-24c6-4c4a-ad29-00cffd59832d} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.200211 [ 7729 ] {e28df533-f705-4055-8a9d-31061448debe} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.201318 [ 7729 ] {e28df533-f705-4055-8a9d-31061448debe} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:13.781774 [ 16278 ] {43071250-1c74-451e-ad2d-3b6d13c02a2c} executeQuery: Code: 36. DB::Exception: Bad HDFS URL: . It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48946) (comment: 02458_empty_hdfs_url.sql) (in query: SELECT * FROM hdfsCluster('test_shard_localhost', '', 'TSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:13.783055 [ 16278 ] {43071250-1c74-451e-ad2d-3b6d13c02a2c} TCPHandler: Code: 36. DB::Exception: Bad HDFS URL: . It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:13.801188 [ 16278 ] {f21fbc8b-5392-45be-87c1-27af4ad1273f} executeQuery: Code: 36. DB::Exception: Bad HDFS URL: . It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48946) (comment: 02458_empty_hdfs_url.sql) (in query: SELECT * FROM hdfsCluster('test_shard_localhost', ' ', 'TSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:13.802148 [ 16278 ] {f21fbc8b-5392-45be-87c1-27af4ad1273f} TCPHandler: Code: 36. DB::Exception: Bad HDFS URL: . It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:13.813478 [ 16278 ] {351e2b2a-c229-4af9-a7df-22fbbe064718} executeQuery: Code: 36. DB::Exception: Bad HDFS URL: /. It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48946) (comment: 02458_empty_hdfs_url.sql) (in query: SELECT * FROM hdfsCluster('test_shard_localhost', '/', 'TSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:13.814371 [ 16278 ] {351e2b2a-c229-4af9-a7df-22fbbe064718} TCPHandler: Code: 36. DB::Exception: Bad HDFS URL: /. It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:13.825014 [ 16278 ] {46b1121e-55cd-4178-be20-7898ab72576d} executeQuery: Code: 36. DB::Exception: Bad HDFS URL: http/. It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48946) (comment: 02458_empty_hdfs_url.sql) (in query: SELECT * FROM hdfsCluster('test_shard_localhost', 'http/', 'TSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:13.825977 [ 16278 ] {46b1121e-55cd-4178-be20-7898ab72576d} TCPHandler: Code: 36. DB::Exception: Bad HDFS URL: http/. It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000030b0ab94 5. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:0: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030b09f47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff110ec 8. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002ff7c5cb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff14797 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ff7b98a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:10:14.471298 [ 1814 ] {79d412f6-56ad-495a-b1aa-7d617cff73f4} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 200.56 MiB (attempt to allocate chunk of 4194304 bytes), maximum: 200.00 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48918) (comment: 01600_remerge_sort_lowered_memory_bytes_ratio.sql) (in query: -- remerge_sort_lowered_memory_bytes_ratio default 2, slightly not enough -- MergeSortingTransform: Re-merging intermediate ORDER BY data (20 blocks with 819200 rows) to save memory consumption -- MergeSortingTransform: Memory usage is lowered from 186.25 MiB to 95.00 MiB -- MergeSortingTransform: Re-merging is not useful (memory usage was not lowered by remerge_sort_lowered_memory_bytes_ratio=2.0) select number k, repeat(toString(number), 11) v1, repeat(toString(number), 12) v2 from numbers(3e6) order by v1, v2 limit 400e3 format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a7daf 9. ./src/Columns/ColumnString.h:0: DB::ColumnString::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375a1d05 10. ./src/Columns/IColumn.h:0: DB::Chunk DB::MergeSorter::mergeBatchImpl>(DB::SortingQueueImpl&) @ 0x000000003b9b7f10 11. ./contrib/llvm-project/libcxx/include/variant:548: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm25EEE10__dispatchB6v15007IONS1_9__variant15__value_visitorIRZN2DB11MergeSorter4readEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE1EEENSG_INSH_INSI_ItEEEELSL_1EEENSG_INSH_INSI_IjEEEELSL_1EEENSG_INSH_INSI_ImEEEELSL_1EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_1EEENSG_INSH_INSI_IDB8_EEEELSL_1EEENSG_INSH_INSI_IsEEEELSL_1EEENSG_INSH_INSI_IiEEEELSL_1EEENSG_INSH_INSI_IlEEEELSL_1EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_1EEENSG_INSH_INSI_IfEEEELSL_1EEENSG_INSH_INSI_IdEEEELSL_1EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IlEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1J_EEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1N_EEEEEELSL_1EEENSG_INSH_INS1X_INS8_10DateTime64EEEEELSL_1EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_1EEENSG_INSH_INS8_12ColumnStringEEELSL_1EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_1EEENSG_INS8_16SimpleSortCursorELSL_1EEENSG_INS8_10SortCursorELSL_1EEENSG_INS8_23SortCursorWithCollationELSL_1EEEEEEEEEDcT_DpT0_ @ 0x000000003b8e6373 12. ./contrib/llvm-project/libcxx/include/variant:0: DB::MergeSorter::read() @ 0x000000003b8ca404 13. ./src/Processors/Chunk.h:110: DB::MergeSortingTransform::remerge() @ 0x000000003b881ba7 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:169: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x000000003b87f566 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x000000003b8de89f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:14.473020 [ 1814 ] {79d412f6-56ad-495a-b1aa-7d617cff73f4} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 200.56 MiB (attempt to allocate chunk of 4194304 bytes), maximum: 200.00 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a7daf 9. ./src/Columns/ColumnString.h:0: DB::ColumnString::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375a1d05 10. ./src/Columns/IColumn.h:0: DB::Chunk DB::MergeSorter::mergeBatchImpl>(DB::SortingQueueImpl&) @ 0x000000003b9b7f10 11. ./contrib/llvm-project/libcxx/include/variant:548: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm25EEE10__dispatchB6v15007IONS1_9__variant15__value_visitorIRZN2DB11MergeSorter4readEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE1EEENSG_INSH_INSI_ItEEEELSL_1EEENSG_INSH_INSI_IjEEEELSL_1EEENSG_INSH_INSI_ImEEEELSL_1EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_1EEENSG_INSH_INSI_IDB8_EEEELSL_1EEENSG_INSH_INSI_IsEEEELSL_1EEENSG_INSH_INSI_IiEEEELSL_1EEENSG_INSH_INSI_IlEEEELSL_1EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_1EEENSG_INSH_INSI_IfEEEELSL_1EEENSG_INSH_INSI_IdEEEELSL_1EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IlEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1J_EEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1N_EEEEEELSL_1EEENSG_INSH_INS1X_INS8_10DateTime64EEEEELSL_1EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_1EEENSG_INSH_INS8_12ColumnStringEEELSL_1EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_1EEENSG_INS8_16SimpleSortCursorELSL_1EEENSG_INS8_10SortCursorELSL_1EEENSG_INS8_23SortCursorWithCollationELSL_1EEEEEEEEEDcT_DpT0_ @ 0x000000003b8e6373 12. ./contrib/llvm-project/libcxx/include/variant:0: DB::MergeSorter::read() @ 0x000000003b8ca404 13. ./src/Processors/Chunk.h:110: DB::MergeSortingTransform::remerge() @ 0x000000003b881ba7 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:169: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x000000003b87f566 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x000000003b8de89f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:15.902654 [ 7729 ] {bc765a5c-a612-43d1-989b-0b148dc7ea5e} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:15.903831 [ 7729 ] {bc765a5c-a612-43d1-989b-0b148dc7ea5e} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:15.938676 [ 7729 ] {9a7c3ada-082b-4d68-aada-9e6d32a25126} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:15.939737 [ 7729 ] {9a7c3ada-082b-4d68-aada-9e6d32a25126} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:15.973712 [ 7729 ] {e3ca0420-095e-40aa-8a93-f5f25eb6668f} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:15.974782 [ 7729 ] {e3ca0420-095e-40aa-8a93-f5f25eb6668f} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:16.012157 [ 7729 ] {1cd86745-1e65-4257-bd0b-942651d9c44c} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:16.013543 [ 7729 ] {1cd86745-1e65-4257-bd0b-942651d9c44c} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:16.318932 [ 1814 ] {bfdabbbe-92c6-417c-99bc-474c8091c73c} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 200.56 MiB (attempt to allocate chunk of 4194304 bytes), maximum: 200.00 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48918) (comment: 01600_remerge_sort_lowered_memory_bytes_ratio.sql) (in query: select number k, repeat(toString(number), 11) v1, repeat(toString(number), 12) v2 from numbers(3e6) order by v1, v2 limit 400e3 settings remerge_sort_lowered_memory_bytes_ratio=2. format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a7daf 9. ./src/Columns/ColumnString.h:0: DB::ColumnString::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375a1d05 10. ./src/Columns/IColumn.h:0: DB::Chunk DB::MergeSorter::mergeBatchImpl>(DB::SortingQueueImpl&) @ 0x000000003b9b7f10 11. ./contrib/llvm-project/libcxx/include/variant:548: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm25EEE10__dispatchB6v15007IONS1_9__variant15__value_visitorIRZN2DB11MergeSorter4readEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE1EEENSG_INSH_INSI_ItEEEELSL_1EEENSG_INSH_INSI_IjEEEELSL_1EEENSG_INSH_INSI_ImEEEELSL_1EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_1EEENSG_INSH_INSI_IDB8_EEEELSL_1EEENSG_INSH_INSI_IsEEEELSL_1EEENSG_INSH_INSI_IiEEEELSL_1EEENSG_INSH_INSI_IlEEEELSL_1EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_1EEENSG_INSH_INSI_IfEEEELSL_1EEENSG_INSH_INSI_IdEEEELSL_1EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IlEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1J_EEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1N_EEEEEELSL_1EEENSG_INSH_INS1X_INS8_10DateTime64EEEEELSL_1EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_1EEENSG_INSH_INS8_12ColumnStringEEELSL_1EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_1EEENSG_INS8_16SimpleSortCursorELSL_1EEENSG_INS8_10SortCursorELSL_1EEENSG_INS8_23SortCursorWithCollationELSL_1EEEEEEEEEDcT_DpT0_ @ 0x000000003b8e6373 12. ./contrib/llvm-project/libcxx/include/variant:0: DB::MergeSorter::read() @ 0x000000003b8ca404 13. ./src/Processors/Chunk.h:110: DB::MergeSortingTransform::remerge() @ 0x000000003b881ba7 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:169: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x000000003b87f566 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x000000003b8de89f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:16.332312 [ 1814 ] {bfdabbbe-92c6-417c-99bc-474c8091c73c} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 200.56 MiB (attempt to allocate chunk of 4194304 bytes), maximum: 200.00 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a7daf 9. ./src/Columns/ColumnString.h:0: DB::ColumnString::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375a1d05 10. ./src/Columns/IColumn.h:0: DB::Chunk DB::MergeSorter::mergeBatchImpl>(DB::SortingQueueImpl&) @ 0x000000003b9b7f10 11. ./contrib/llvm-project/libcxx/include/variant:548: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm25EEE10__dispatchB6v15007IONS1_9__variant15__value_visitorIRZN2DB11MergeSorter4readEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE1EEENSG_INSH_INSI_ItEEEELSL_1EEENSG_INSH_INSI_IjEEEELSL_1EEENSG_INSH_INSI_ImEEEELSL_1EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_1EEENSG_INSH_INSI_IDB8_EEEELSL_1EEENSG_INSH_INSI_IsEEEELSL_1EEENSG_INSH_INSI_IiEEEELSL_1EEENSG_INSH_INSI_IlEEEELSL_1EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_1EEENSG_INSH_INSI_IfEEEELSL_1EEENSG_INSH_INSI_IdEEEELSL_1EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IlEEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1J_EEEEEELSL_1EEENSG_INSH_INS1X_INS1Y_IS1N_EEEEEELSL_1EEENSG_INSH_INS1X_INS8_10DateTime64EEEEELSL_1EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_1EEENSG_INSH_INS8_12ColumnStringEEELSL_1EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_1EEENSG_INS8_16SimpleSortCursorELSL_1EEENSG_INS8_10SortCursorELSL_1EEENSG_INS8_23SortCursorWithCollationELSL_1EEEEEEEEEDcT_DpT0_ @ 0x000000003b8e6373 12. ./contrib/llvm-project/libcxx/include/variant:0: DB::MergeSorter::read() @ 0x000000003b8ca404 13. ./src/Processors/Chunk.h:110: DB::MergeSortingTransform::remerge() @ 0x000000003b881ba7 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:169: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x000000003b87f566 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x000000003b8de89f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:16.505990 [ 16278 ] {4985f853-f6b0-4748-8091-502c24d320a0} StorageBuffer (test_95sjhoxh.buffer_table1): Destination table test_95sjhoxh.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.06.18 11:10:16.668288 [ 16278 ] {53ef559a-998d-4d2c-952e-7f4c2d83956a} StorageBuffer (test_95sjhoxh.buffer_table1): Destination table test_95sjhoxh.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.06.18 11:10:16.728727 [ 16278 ] {a4f2057f-30aa-400b-a123-895ef9984429} StorageBuffer (test_95sjhoxh.buffer_table1): Destination table test_95sjhoxh.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.06.18 11:10:17.290064 [ 16264 ] {d31e71dd-f4a9-4191-8460-5007cf4aaf77} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49038) (comment: 02124_insert_deduplication_token_materialized_views.sql) (in query: INSERT INTO test SELECT 'case1', number%3, 1 FROM numbers(9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:17.295945 [ 16264 ] {d31e71dd-f4a9-4191-8460-5007cf4aaf77} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:18.333667 [ 16264 ] {a9fa180b-f39c-4265-a11d-41120ec00269} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49038) (comment: 02124_insert_deduplication_token_materialized_views.sql) (in query: INSERT INTO test SELECT 'case2', number%3, 1 FROM numbers(9) ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:18.336883 [ 16264 ] {a9fa180b-f39c-4265-a11d-41120ec00269} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:18.662064 [ 1587 ] {f6bbf7ab-1304-4ba6-8922-4f28c1f7b5a0} executeQuery: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49090) (comment: 01821_join_table_mutation.sql) (in query: ALTER TABLE join_table_mutation UPDATE name = 'some' WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageJoin.cpp:165: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000383f5ed3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857b17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:18.663292 [ 1587 ] {f6bbf7ab-1304-4ba6-8922-4f28c1f7b5a0} TCPHandler: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageJoin.cpp:165: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000383f5ed3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857b17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:18.997541 [ 7729 ] {cdd1d484-1141-46aa-b413-269da031582a} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:18.998708 [ 7729 ] {cdd1d484-1141-46aa-b413-269da031582a} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.033749 [ 7729 ] {b55ff9cf-8fae-4595-8705-ac209bc096e7} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.040093 [ 7729 ] {b55ff9cf-8fae-4595-8705-ac209bc096e7} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.075089 [ 7729 ] {55e5eddf-d851-4727-b2d5-bfc15bf4e51b} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.076236 [ 7729 ] {55e5eddf-d851-4727-b2d5-bfc15bf4e51b} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.113662 [ 7729 ] {7d98749a-a4e6-40b7-86d1-95dde6c53227} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.114888 [ 7729 ] {7d98749a-a4e6-40b7-86d1-95dde6c53227} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.225375 [ 16264 ] {b2a5ced7-eeab-49f9-9b01-eca13a8192a5} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49038) (comment: 02124_insert_deduplication_token_materialized_views.sql) (in query: INSERT INTO test SELECT 'case3', number%3, 1 FROM numbers(9) SETTINGS insert_deduplication_token = 'case3test1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:19.229260 [ 16264 ] {b2a5ced7-eeab-49f9-9b01-eca13a8192a5} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:20.175833 [ 16264 ] {3ed4ec38-3cd7-42dc-8292-309c790e3c7e} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49038) (comment: 02124_insert_deduplication_token_materialized_views.sql) (in query: INSERT INTO test SELECT 'case4', number%3, 1 FROM numbers(9) SETTINGS insert_deduplication_token = 'case4test1' ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:20.179541 [ 16264 ] {3ed4ec38-3cd7-42dc-8292-309c790e3c7e} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc).: while pushing to view test_t8zw39on.test_mv_b (c2130b67-31f1-4df0-9968-c841e0a6c5d3). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eef71b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1dea82 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.874934 [ 7729 ] {5e3eb844-fde0-4ba6-89a4-11641833df8d} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.876736 [ 7729 ] {5e3eb844-fde0-4ba6-89a4-11641833df8d} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.912218 [ 7729 ] {0b1d6dad-8e51-4936-8b4e-56368739e356} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.913403 [ 7729 ] {0b1d6dad-8e51-4936-8b4e-56368739e356} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.946258 [ 7729 ] {ef40146d-5e82-4f3b-818d-14bcae6e7c7c} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.947647 [ 7729 ] {ef40146d-5e82-4f3b-818d-14bcae6e7c7c} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.981116 [ 7729 ] {cd769224-3643-4857-9821-804b425fee54} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:21.982254 [ 7729 ] {cd769224-3643-4857-9821-804b425fee54} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:22.844570 [ 1583 ] {3de27753-78a6-49ab-812b-9b576883e156} executeQuery: Code: 574. DB::Exception: Too many bytes pending for async INSERT: 3.28 KiB (bytes_to_throw_insert=1.00 B). (DISTRIBUTED_TOO_MANY_PENDING_BYTES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54484) (comment: 01670_distributed_bytes_to_throw_insert.sql) (in query: -- second will fail, because of bytes_to_throw_insert=1 -- (previous block definitelly takes more, since it has header) insert into dist_01670 select * from numbers(1) settings prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1789: DB::StorageDistributed::delayInsertOrThrowIfNeeded() const @ 0x00000000382ae390 5. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:143: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003930bbee 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:22.847384 [ 1583 ] {3de27753-78a6-49ab-812b-9b576883e156} TCPHandler: Code: 574. DB::Exception: Too many bytes pending for async INSERT: 3.28 KiB (bytes_to_throw_insert=1.00 B). (DISTRIBUTED_TOO_MANY_PENDING_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1789: DB::StorageDistributed::delayInsertOrThrowIfNeeded() const @ 0x00000000382ae390 5. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:143: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003930bbee 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.096484 [ 16275 ] {61a4977a-0cb7-4a50-a397-dda4aab27192} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `VasyaUnexistingColumn` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54582) (comment: 00446_clear_column_in_partition_concurrent_zookeeper.sh) (in query: ALTER TABLE clear_column1 CLEAR COLUMN VasyaUnexistingColumn IN PARTITION '200001'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3950 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.098326 [ 16275 ] {61a4977a-0cb7-4a50-a397-dda4aab27192} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `VasyaUnexistingColumn` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3950 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.650048 [ 7729 ] {77e64ffd-f7c1-4226-a66c-d763f73af8af} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.651116 [ 7729 ] {77e64ffd-f7c1-4226-a66c-d763f73af8af} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.681219 [ 7729 ] {7adb74b6-c9fc-4ea5-84e4-855d4f91f815} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.682298 [ 7729 ] {7adb74b6-c9fc-4ea5-84e4-855d4f91f815} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.712926 [ 7729 ] {fe7c198e-a23a-4f3b-a3a1-ba18344ef700} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.713977 [ 7729 ] {fe7c198e-a23a-4f3b-a3a1-ba18344ef700} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.744272 [ 7729 ] {ecd2b9a9-f24d-42bb-bbdd-02bd8b144aaf} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:24.745477 [ 7729 ] {ecd2b9a9-f24d-42bb-bbdd-02bd8b144aaf} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:26.538727 [ 610 ] {d4399a6a-72e2-4bdb-a7b9-5bb486e3765a} executeQuery: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54620) (comment: 03148_setting_max_streams_to_max_threads_ratio_overflow.sql) (in query: SELECT * FROM test_table SETTINGS max_threads = 1025, max_streams_to_max_threads_ratio = -9223372036854775808, enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x000000001c6271ea 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:732: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d78f94 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:26.540029 [ 610 ] {d4399a6a-72e2-4bdb-a7b9-5bb486e3765a} TCPHandler: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x000000001c6271ea 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:732: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d78f94 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:26.995211 [ 610 ] {bbaf0b85-ae97-49a3-8a04-2b7a3a172cbc} executeQuery: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54620) (comment: 03148_setting_max_streams_to_max_threads_ratio_overflow.sql) (in query: SELECT * FROM test_table SETTINGS max_threads = 1025, max_streams_to_max_threads_ratio = -9223372036854775808, enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x000000001c6271ea 4. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:2538: DB::InterpreterSelectQuery::executeFetchColumns(DB::QueryProcessingStage::Enum, DB::QueryPlan&) @ 0x0000000034c2dabd 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::executeImpl(DB::QueryPlan&, std::optional) @ 0x0000000034c106a6 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::buildQueryPlan(DB::QueryPlan&) @ 0x0000000034c0dbe7 7. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:305: DB::InterpreterSelectWithUnionQuery::buildQueryPlan(DB::QueryPlan&) @ 0x0000000034e4ed68 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::execute() @ 0x0000000034e5173d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:26.996230 [ 610 ] {bbaf0b85-ae97-49a3-8a04-2b7a3a172cbc} TCPHandler: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x000000001c6271ea 4. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:2538: DB::InterpreterSelectQuery::executeFetchColumns(DB::QueryProcessingStage::Enum, DB::QueryPlan&) @ 0x0000000034c2dabd 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::executeImpl(DB::QueryPlan&, std::optional) @ 0x0000000034c106a6 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::buildQueryPlan(DB::QueryPlan&) @ 0x0000000034c0dbe7 7. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:305: DB::InterpreterSelectWithUnionQuery::buildQueryPlan(DB::QueryPlan&) @ 0x0000000034e4ed68 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::execute() @ 0x0000000034e5173d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.385559 [ 7729 ] {8078878f-7c9d-4ea8-ab2f-a82b85301d0d} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.386650 [ 7729 ] {8078878f-7c9d-4ea8-ab2f-a82b85301d0d} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.421508 [ 7729 ] {b53de92a-c5ea-4b26-9c5d-00344d719040} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.422793 [ 7729 ] {b53de92a-c5ea-4b26-9c5d-00344d719040} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.456192 [ 7729 ] {f987ebbc-3109-4f61-9f20-572a9bf4abd2} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.457454 [ 7729 ] {f987ebbc-3109-4f61-9f20-572a9bf4abd2} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.489738 [ 7729 ] {3d8132cd-d3be-47d0-a808-30a6cda7df90} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:27.491032 [ 7729 ] {3d8132cd-d3be-47d0-a808-30a6cda7df90} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:28.778216 [ 612 ] {e9863b30-3f0f-4012-9c3b-fc54bf28a1d4} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT id FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:28.779735 [ 612 ] {e9863b30-3f0f-4012-9c3b-fc54bf28a1d4} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:28.808535 [ 612 ] {6ffec16c-7b3c-490d-b44a-7ea47c8e44aa} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT value FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:28.809658 [ 612 ] {6ffec16c-7b3c-490d-b44a-7ea47c8e44aa} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:29.960133 [ 612 ] {be698cc5-46a8-4974-af87-8829069c62f6} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT id FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:29.961137 [ 612 ] {be698cc5-46a8-4974-af87-8829069c62f6} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:29.982667 [ 612 ] {609ae33a-c728-4f06-9fad-48a48ed87ca9} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT value FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:29.983625 [ 612 ] {609ae33a-c728-4f06-9fad-48a48ed87ca9} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.116858 [ 7729 ] {ef42716c-4e41-4972-b121-d2f34aa66b3c} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: -- Int64 and UInt64 has no supertype SELECT * FROM t1 FULL JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.117917 [ 7729 ] {ef42716c-4e41-4972-b121-d2f34aa66b3c} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN FULL OUTER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.139942 [ 7729 ] {639437f5-9e92-4925-8bdf-b19fd0848a39} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.140939 [ 7729 ] {639437f5-9e92-4925-8bdf-b19fd0848a39} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN LEFT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.169609 [ 7729 ] {4096539a-d385-4811-87a6-053c6f928448} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.170746 [ 7729 ] {4096539a-d385-4811-87a6-053c6f928448} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN RIGHT JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.200423 [ 7729 ] {dbc5f1ae-0157-4614-883d-735772c7a507} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35382) (comment: 01721_join_implicit_cast_long.gen.sql) (in query: SELECT * FROM t1 INNER JOIN t2 ON (t1.a + t1.b + 100 = t2.a + t2.b) ORDER BY (t1.a, t2.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:30.201506 [ 7729 ] {dbc5f1ae-0157-4614-883d-735772c7a507} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: JOIN INNER JOIN ... ON ((t1.a + t1.b) + 100) = (t2.a + t2.b) cannot infer common type in ON section for keys. Left key plus(plus(__table1.a, __table1.b), 100_UInt8) type UInt64. Right key plus(__table2.a, __table2.b) type Nullable(Int64). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325eff22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325efa08 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fab4b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:479: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f97a5 7. ./build_docker/./src/Planner/PlannerJoins.cpp:548: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcbcd7 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:31.151314 [ 612 ] {735debb9-691c-4006-9c15-38f6b3081b9e} executeQuery: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 RIGHT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT id FROM test_table_join_1 RIGHT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:31.152301 [ 612 ] {735debb9-691c-4006-9c15-38f6b3081b9e} TCPHandler: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 RIGHT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:31.177373 [ 612 ] {e9b7e153-f6a0-4a25-bba6-68a403444ed8} executeQuery: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 RIGHT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT value FROM test_table_join_1 RIGHT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:31.178450 [ 612 ] {e9b7e153-f6a0-4a25-bba6-68a403444ed8} TCPHandler: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 RIGHT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:32.292039 [ 612 ] {f5dfb7d3-c5d5-4600-9b30-034623070d11} executeQuery: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 FULL OUTER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT id FROM test_table_join_1 FULL JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:32.293268 [ 612 ] {f5dfb7d3-c5d5-4600-9b30-034623070d11} TCPHandler: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 FULL OUTER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:32.325821 [ 612 ] {bebe3b56-9fa8-4ff6-bea5-7ba54b0e2446} executeQuery: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 FULL OUTER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54660) (comment: 02372_analyzer_join.gen.sql) (in query: SELECT value FROM test_table_join_1 FULL JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:32.326874 [ 612 ] {bebe3b56-9fa8-4ff6-bea5-7ba54b0e2446} TCPHandler: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 FULL OUTER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f6097 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335ba56d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:44.375342 [ 1588 ] {8cbbeeb8-230e-44c4-936b-ba8ba9a51234} executeQuery: Code: 44. DB::Exception: Illegal columns of arguments of function range, the function only implemented for unsigned/signed integers up to 64 bit: In scope SELECT range(toUInt256(1), 1). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60318) (comment: 01780_range_msan.sql) (in query: SELECT range(toUInt256(1), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe9909a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:10:44.376478 [ 1588 ] {8cbbeeb8-230e-44c4-936b-ba8ba9a51234} TCPHandler: Code: 44. DB::Exception: Illegal columns of arguments of function range, the function only implemented for unsigned/signed integers up to 64 bit: In scope SELECT range(toUInt256(1), 1). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe9909a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:10:51.316020 [ 1814 ] {da698143-36ee-47b1-83fe-e4b1cdd845f9} executeQuery: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60668) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 SETTINGS ignore_data_skipping_indices='';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1520: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003bf0a77b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000003bf03867 6. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c158a44 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c15850f 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c0ff8f2 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:51.317109 [ 1814 ] {da698143-36ee-47b1-83fe-e4b1cdd845f9} TCPHandler: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1520: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003bf0a77b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000003bf03867 6. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c158a44 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c15850f 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c0ff8f2 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:52.023678 [ 1814 ] {f58a6d02-dd37-4b37-81ce-5960b4dca0b6} executeQuery: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60668) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 WHERE x = 1 AND y = 1 SETTINGS ignore_data_skipping_indices='xy_idx',force_data_skipping_indices='xy_idx' ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf130f9 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf18ae0 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:52.025136 [ 1814 ] {f58a6d02-dd37-4b37-81ce-5960b4dca0b6} TCPHandler: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf130f9 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf18ae0 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:54.290674 [ 612 ] {fbb34c27-eb14-44ce-af27-c20056b09d0e} executeQuery: Code: 59. DB::Exception: Illegal type UInt32 of column modulo(__table1.n, 143011_UInt32) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35146) (comment: 02513_prewhere_combine_step_filters.sql) (in query: SELECT * FROM table_02513 WHERE n%143011;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:46: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80cd7e 5. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 6. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 7. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:54.291959 [ 612 ] {fbb34c27-eb14-44ce-af27-c20056b09d0e} TCPHandler: Code: 59. DB::Exception: Illegal type UInt32 of column modulo(__table1.n, 143011_UInt32) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:46: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80cd7e 5. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 6. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 7. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:54.936721 [ 612 ] {9b4a2456-9a37-47b8-92e1-c78e0e79fb65} executeQuery: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35146) (comment: 02513_prewhere_combine_step_filters.sql) (in query: SELECT * FROM table_02513 PREWHERE n%143011;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Columns/FilterDescription.cpp:97: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000037f8729a 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000039cc34dc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbc0b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbb654 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:54.938976 [ 612 ] {9b4a2456-9a37-47b8-92e1-c78e0e79fb65} TCPHandler: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Columns/FilterDescription.cpp:97: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000037f8729a 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000039cc34dc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbc0b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbb654 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:55.026047 [ 612 ] {9b1db2fb-b572-4eb1-856e-45f35023005d} executeQuery: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35146) (comment: 02513_prewhere_combine_step_filters.sql) (in query: SELECT * FROM table_02513 PREWHERE n%143011 WHERE n%13;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Columns/FilterDescription.cpp:97: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000037f8729a 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000039cc34dc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbc0b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbb654 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:10:55.027926 [ 612 ] {9b1db2fb-b572-4eb1-856e-45f35023005d} TCPHandler: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Columns/FilterDescription.cpp:97: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000037f8729a 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000039cc34dc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbc0b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbb654 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:02.072399 [ 1587 ] {4585e32c-72f5-488a-9419-31508a25ba13} executeQuery: Code: 46. DB::Exception: Function with name 'toDateTimeNonExistingFunction' does not exist. In scope SELECT toDateTimeNonExistingFunction(now()) RESPECT NULLS AS b. (UNKNOWN_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: -- Normal functions should throw in the server SELECT toDateTimeNonExistingFunction(now()) RESPECT NULLS b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002141bb17 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3232: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334acd5c 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:02.073619 [ 1587 ] {4585e32c-72f5-488a-9419-31508a25ba13} TCPHandler: Code: 46. DB::Exception: Function with name 'toDateTimeNonExistingFunction' does not exist. In scope SELECT toDateTimeNonExistingFunction(now()) RESPECT NULLS AS b. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002141bb17 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3232: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334acd5c 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:02.620258 [ 1587 ] {135abb4b-7561-4ce9-b3da-7033fb91ed90} executeQuery: Code: 62. DB::Exception: Function with name 'toDateTime' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT toDateTime(now()) RESPECT NULLS b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334abbe5 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:02.621357 [ 1587 ] {135abb4b-7561-4ce9-b3da-7033fb91ed90} TCPHandler: Code: 62. DB::Exception: Function with name 'toDateTime' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334abbe5 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.114653 [ 1587 ] {28912c5e-7d29-4743-b470-c5e89a1651ad} executeQuery: Code: 62. DB::Exception: Function with name 'in' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT count() from numbers(10) where in(number, (0)) RESPECT NULLS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334aad46 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.116349 [ 1587 ] {28912c5e-7d29-4743-b470-c5e89a1651ad} TCPHandler: Code: 62. DB::Exception: Function with name 'in' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334aad46 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.597350 [ 16260 ] {ee742457-d85e-40de-ac50-1921fe6c2d04} executeQuery: Code: 36. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42268) (comment: 03215_parallel_replicas_crash_after_refactoring.sql) (in query: SELECT max(`__table1`.`k`) IGNORE NULLS AS `max(k)` FROM `test_sxjlys7u`.`03215_parallel_replicas` AS `__table1` WITH TOTALS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.597428 [ 1534 ] {2daa43a6-d6d8-438d-a7b3-1175b0abceb8} executeQuery: Code: 36. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40862) (comment: 03215_parallel_replicas_crash_after_refactoring.sql) (in query: SELECT max(`__table1`.`k`) IGNORE NULLS AS `max(k)` FROM `test_sxjlys7u`.`03215_parallel_replicas` AS `__table1` WITH TOTALS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.597612 [ 1828 ] {1dd3ebb7-53b1-4cb1-8f82-e241cbbd2ce4} executeQuery: Code: 36. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53448) (comment: 03215_parallel_replicas_crash_after_refactoring.sql) (in query: SELECT max(`__table1`.`k`) IGNORE NULLS AS `max(k)` FROM `test_sxjlys7u`.`03215_parallel_replicas` AS `__table1` WITH TOTALS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.598709 [ 16260 ] {ee742457-d85e-40de-ac50-1921fe6c2d04} TCPHandler: Code: 36. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.598861 [ 1534 ] {2daa43a6-d6d8-438d-a7b3-1175b0abceb8} TCPHandler: Code: 36. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.599057 [ 1828 ] {1dd3ebb7-53b1-4cb1-8f82-e241cbbd2ce4} TCPHandler: Code: 36. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.721820 [ 1587 ] {0d8a3e26-6ad7-464f-9258-84b689454f84} executeQuery: Code: 62. DB::Exception: Function with name 'if' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT if(number > 0, number, 0) respect nulls from numbers(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ab98e 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.724568 [ 1587 ] {0d8a3e26-6ad7-464f-9258-84b689454f84} TCPHandler: Code: 62. DB::Exception: Function with name 'if' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ab98e 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:03.885789 [ 1588 ] {deff8dc0-b1a1-432f-8d09-50c5e2c63b7a} executeQuery: Code: 36. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 : While executing Remote. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49952) (comment: 03215_parallel_replicas_crash_after_refactoring.sql) (in query: SELECT max(k) IGNORE NULLS FROM 03215_parallel_replicas WITH TOTALS SETTINGS enable_parallel_replicas = 1, max_parallel_replicas = 65535, prefer_localhost_replica = 0, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_single_task_marks_count_multiplier = -0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020198b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b950c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d4d1b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b50b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000003234c5d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234a131 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032349486 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032346972 2025.06.18 11:11:03.888820 [ 1588 ] {deff8dc0-b1a1-432f-8d09-50c5e2c63b7a} TCPHandler: Code: 36. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Chosen number of marks to read is zero (likely because of weird interference of settings). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:79: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, std::shared_ptr const&) @ 0x000000003c0368b6 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:v15007]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, std::shared_ptr&) @ 0x000000003bf559b0 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003becf25f 7. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003bed994b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003bedc007 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003bf14799 10. ./src/QueryPipeline/Pipe.h:108: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1b197 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 : While executing Remote. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020198b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b950c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d4d1b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b50b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000003234c5d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234a131 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032349486 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032346972 2025.06.18 11:11:04.279761 [ 1587 ] {c2dc70e6-44e2-4307-8ea1-a9fe4f5c3203} executeQuery: Code: 62. DB::Exception: Function with name 'lambda' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: WITH (x -> x + 1) AS lambda SELECT lambda(number) RESPECT NULLS FROM numbers(10) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ab555 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:04.281088 [ 1587 ] {c2dc70e6-44e2-4307-8ea1-a9fe4f5c3203} TCPHandler: Code: 62. DB::Exception: Function with name 'lambda' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ab555 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:04.757539 [ 1587 ] {a3e93fa8-30c0-41fe-af5c-85c027cf27e5} executeQuery: Code: 62. DB::Exception: Function with name 'indexHint' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT * from system.one WHERE indexHint(dummy = 1) RESPECT NULLS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334abbe5 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:04.758800 [ 1587 ] {a3e93fa8-30c0-41fe-af5c-85c027cf27e5} TCPHandler: Code: 62. DB::Exception: Function with name 'indexHint' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334abbe5 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:04.775883 [ 1587 ] {4287b95f-2397-4331-8ab5-1cd3066dc179} executeQuery: Code: 62. DB::Exception: Function with name 'arrayJoin' cannot use IGNORE NULLS. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT arrayJoin([[3,4,5], [6,7], [2], [1,1]]) IGNORE NULLS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334abbe5 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:04.777059 [ 1587 ] {4287b95f-2397-4331-8ab5-1cd3066dc179} TCPHandler: Code: 62. DB::Exception: Function with name 'arrayJoin' cannot use IGNORE NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334abbe5 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:05.329370 [ 1587 ] {466c65b2-5b69-4bd4-9af2-0eb0f35e664a} executeQuery: Code: 62. DB::Exception: Function with name 'grouping' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT number, grouping(number % 2, number) RESPECT NULLS AS gr FROM numbers(10) GROUP BY GROUPING SETS ((number), (number % 2)) SETTINGS force_grouping_standard_compatibility = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae0b9 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:05.330876 [ 1587 ] {466c65b2-5b69-4bd4-9af2-0eb0f35e664a} TCPHandler: Code: 62. DB::Exception: Function with name 'grouping' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x0000000020c7494d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae0b9 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:06.767426 [ 610 ] {69d7cae6-1c4f-4456-b845-69d3dc9c3d9a} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50036) (comment: 00063_check_query.sql) (in query: CHECK TABLE check_query_tiny_log PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageLog.cpp:912: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000038d5a6f7 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:0: DB::InterpreterCheckQuery::execute() @ 0x00000000359f8ffd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:06.768804 [ 610 ] {69d7cae6-1c4f-4456-b845-69d3dc9c3d9a} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageLog.cpp:912: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000038d5a6f7 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:0: DB::InterpreterCheckQuery::execute() @ 0x00000000359f8ffd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:06.778609 [ 610 ] {a10f3477-92e3-424d-beb0-d71886bcfb21} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50036) (comment: 00063_check_query.sql) (in query: CHECK TABLE check_query_tiny_log PART 'all_0_0_0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageLog.cpp:912: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000038d5a6f7 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:0: DB::InterpreterCheckQuery::execute() @ 0x00000000359f8ffd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:06.779496 [ 610 ] {a10f3477-92e3-424d-beb0-d71886bcfb21} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageLog.cpp:912: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000038d5a6f7 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:0: DB::InterpreterCheckQuery::execute() @ 0x00000000359f8ffd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:07.285064 [ 16264 ] {2f4efe5b-6bc1-4eb8-a2aa-b2383d66fd30} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50012) (comment: 02752_space_function.sql) (in query: SELECT space('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0dbee8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:07.286353 [ 16264 ] {2f4efe5b-6bc1-4eb8-a2aa-b2383d66fd30} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0dbee8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:07.299744 [ 16264 ] {9373b805-f62a-4690-a54c-b2fe27dd5de0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: Array(String): In scope SELECT space(['abc']). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50012) (comment: 02752_space_function.sql) (in query: SELECT space(['abc']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0dbee8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:07.300710 [ 16264 ] {9373b805-f62a-4690-a54c-b2fe27dd5de0} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: Array(String): In scope SELECT space(['abc']). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0dbee8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:07.313296 [ 16264 ] {c3762d72-7894-4804-8485-694afb0fb489} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50012) (comment: 02752_space_function.sql) (in query: SELECT space(('abc'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0dbee8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:07.314360 [ 16264 ] {c3762d72-7894-4804-8485-694afb0fb489} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0dbee8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:08.072570 [ 16264 ] {a9fcc8e5-da5b-467d-86ca-6427d14cf813} executeQuery: Code: 131. DB::Exception: Too many times to repeat (18011680617995229494), maximum is: 1000000: In scope SELECT space(CAST('30303030303030303030303030303030', 'UInt64')). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50012) (comment: 02752_space_function.sql) (in query: SELECT space(30303030303030303030303030303030::UInt64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. DB::(anonymous namespace)::FunctionSpace::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0dacc0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:08.074034 [ 16264 ] {a9fcc8e5-da5b-467d-86ca-6427d14cf813} TCPHandler: Code: 131. DB::Exception: Too many times to repeat (18011680617995229494), maximum is: 1000000: In scope SELECT space(CAST('30303030303030303030303030303030', 'UInt64')). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. DB::(anonymous namespace)::FunctionSpace::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0dacc0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:09.974108 [ 1583 ] {a6cc5814-0800-4ed6-a71f-6c08aa6d7482} executeQuery: Code: 48. DB::Exception: Function sum does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50092) (comment: 02922_respect_nulls_extensive.sql) (in query: -- Unsupported functions should throw in the server SELECT number, sum (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:09.975794 [ 1583 ] {a6cc5814-0800-4ed6-a71f-6c08aa6d7482} TCPHandler: Code: 48. DB::Exception: Function sum does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:09.995609 [ 1583 ] {5618904d-aa95-41ff-b633-1dac5f1ad148} executeQuery: Code: 48. DB::Exception: Function avg does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50092) (comment: 02922_respect_nulls_extensive.sql) (in query: SELECT number, avgIf (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:09.996910 [ 1583 ] {5618904d-aa95-41ff-b633-1dac5f1ad148} TCPHandler: Code: 48. DB::Exception: Function avg does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:10.016441 [ 1583 ] {45c906d1-58d5-4dd7-909d-0fd385762f7d} executeQuery: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50092) (comment: 02922_respect_nulls_extensive.sql) (in query: -- Same for double RESPECT NULLS SELECT number, first_value_respect_nulls (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:10.017709 [ 1583 ] {45c906d1-58d5-4dd7-909d-0fd385762f7d} TCPHandler: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:10.037105 [ 1583 ] {6034bef7-e36d-469a-aed4-670d2411a262} executeQuery: Code: 48. DB::Exception: Function anyLast_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50092) (comment: 02922_respect_nulls_extensive.sql) (in query: SELECT number, last_value_respect_nulls (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:10.038513 [ 1583 ] {6034bef7-e36d-469a-aed4-670d2411a262} TCPHandler: Code: 48. DB::Exception: Function anyLast_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000306e0a56 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000306db974 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d878d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349903f 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:12.163966 [ 16279 ] {0c9de822-3f3f-49fb-837f-048505f72f6d} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('x123', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal32 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.165423 [ 16279 ] {0c9de822-3f3f-49fb-837f-048505f72f6d} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.913766 [ 16279 ] {77e37bbe-3cdd-4326-8374-85a8b5b48552} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(9, 4) from String, because value is too short: In scope SELECT toDecimal32('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal32 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0d02a 6. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032506531 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 9. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 10. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:12.915139 [ 16279 ] {77e37bbe-3cdd-4326-8374-85a8b5b48552} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(9, 4) from String, because value is too short: In scope SELECT toDecimal32('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0d02a 6. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032506531 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 9. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 10. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:12.931209 [ 16279 ] {2f746ba4-bf64-4187-9756-1eedbd6d6b79} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal32 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.932361 [ 16279 ] {2f746ba4-bf64-4187-9756-1eedbd6d6b79} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.947362 [ 16279 ] {5487ec56-ebeb-4e89-8258-36eb92990c29} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal32 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.948411 [ 16279 ] {5487ec56-ebeb-4e89-8258-36eb92990c29} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.962897 [ 16279 ] {4cb69039-c855-44e6-9184-ae187f6bd780} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal32 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.963947 [ 16279 ] {4cb69039-c855-44e6-9184-ae187f6bd780} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.978844 [ 16279 ] {51a2a093-ff3e-406e-b404-47132b898a39} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\'', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal32 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:12.980059 [ 16279 ] {51a2a093-ff3e-406e-b404-47132b898a39} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212e8a 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:13.173831 [ 612 ] {5f098004-e801-4285-a4f6-73ade4708ae9} executeQuery: Code: 36. DB::Exception: The function 'exponentialTimeDecayedAvg' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33750) (comment: 03251_unaligned_window_function_state.sql) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/70569 -- Reproduces UBSAN alert about misaligned address SELECT anyLast(id), anyLast(time), exponentialTimeDecayedAvg(10)(id, time) FROM values('id Int8, time DateTime', (1,1),(1,2),(2,3),(3,3),(3,5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::WindowFunction::fail() const @ 0x000000003ba2f06e 4. ? @ 0x000000003ba2bb49 5. ./src/AggregateFunctions/IAggregateFunction.h:530: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000003ba2c924 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000033b55d59 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1463: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d73f 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 9. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:13.175898 [ 612 ] {5f098004-e801-4285-a4f6-73ade4708ae9} TCPHandler: Code: 36. DB::Exception: The function 'exponentialTimeDecayedAvg' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::WindowFunction::fail() const @ 0x000000003ba2f06e 4. ? @ 0x000000003ba2bb49 5. ./src/AggregateFunctions/IAggregateFunction.h:530: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000003ba2c924 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000033b55d59 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1463: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d73f 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 9. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:13.275836 [ 1814 ] {74d96895-b5fc-43a0-8378-fe44363253f5} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33766) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:13.277077 [ 1814 ] {74d96895-b5fc-43a0-8378-fe44363253f5} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:13.851766 [ 16279 ] {9c967348-507d-4ecf-82e4-80fcb466f24f} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('x123', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal64 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:13.852862 [ 16279 ] {9c967348-507d-4ecf-82e4-80fcb466f24f} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:13.917302 [ 1534 ] {4b921316-335d-4555-850f-2330d5e4364e} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_67s27j5p.test_constraints (ed5620af-419b-404e-86cc-3d4f920855cc) is violated at row 2. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33770) (comment: 00952_basic_constraints.sh) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:13.919883 [ 1534 ] {4b921316-335d-4555-850f-2330d5e4364e} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_67s27j5p.test_constraints (ed5620af-419b-404e-86cc-3d4f920855cc) is violated at row 2. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:14.065680 [ 3194 ] {e7430c7f-882c-480b-a4b8-a5a0bb6d996e} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: You have carriage return (\r, 0x0D, ASCII 13) at end of first row. It's like your input data has DOS/Windows style line separators, that are illegal in TabSeparated format. You must transform your file to Unix format. But if you really need carriage return at end of string value of last column, you need to escape it as \r or else enable setting 'input_format_tsv_crlf_end_of_line': (while reading header). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:30: DB::checkForCarriageReturn(DB::ReadBuffer&) @ 0x000000003b69c60e 5. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:106: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x000000003b69c2aa 6. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:0: std::vector> DB::TabSeparatedFormatReader::readRowImpl() @ 0x000000003b6a8138 7. ./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.h:69: DB::TabSeparatedFormatReader::readRowForHeaderDetection() @ 0x000000003b6a6f8e 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000003b0a4b19 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b0a2454 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038761 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 14. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b3a4185 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b39f4e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3a6fbc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:14.068156 [ 612 ] {e7430c7f-882c-480b-a4b8-a5a0bb6d996e} executeQuery: Code: 117. DB::Exception: You have carriage return (\r, 0x0D, ASCII 13) at end of first row. It's like your input data has DOS/Windows style line separators, that are illegal in TabSeparated format. You must transform your file to Unix format. But if you really need carriage return at end of string value of last column, you need to escape it as \r or else enable setting 'input_format_tsv_crlf_end_of_line': (while reading header): (in file/uri /var/lib/clickhouse/user_files/02973_parse_crlf_with_tsv_files_test_5y2d6zmq_data_with_crlf.tsv): While executing ParallelParsingBlockInputFormat: While executing File. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33780) (comment: 02973_parse_crlf_with_tsv_files.sh) (in query: SELECT * FROM file(02973_parse_crlf_with_tsv_files_test_5y2d6zmq_data_with_crlf.tsv, 'TabSeparated', 'SearchTerm String, Date Date, Hits UInt32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:30: DB::checkForCarriageReturn(DB::ReadBuffer&) @ 0x000000003b69c60e 5. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:106: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x000000003b69c2aa 6. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:0: std::vector> DB::TabSeparatedFormatReader::readRowImpl() @ 0x000000003b6a8138 7. ./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.h:69: DB::TabSeparatedFormatReader::readRowForHeaderDetection() @ 0x000000003b6a6f8e 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000003b0a4b19 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b0a2454 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038761 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 14. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b3a4185 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b39f4e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3a6fbc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:14.071408 [ 612 ] {e7430c7f-882c-480b-a4b8-a5a0bb6d996e} TCPHandler: Code: 117. DB::Exception: You have carriage return (\r, 0x0D, ASCII 13) at end of first row. It's like your input data has DOS/Windows style line separators, that are illegal in TabSeparated format. You must transform your file to Unix format. But if you really need carriage return at end of string value of last column, you need to escape it as \r or else enable setting 'input_format_tsv_crlf_end_of_line': (while reading header): (in file/uri /var/lib/clickhouse/user_files/02973_parse_crlf_with_tsv_files_test_5y2d6zmq_data_with_crlf.tsv): While executing ParallelParsingBlockInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:30: DB::checkForCarriageReturn(DB::ReadBuffer&) @ 0x000000003b69c60e 5. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:106: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x000000003b69c2aa 6. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:0: std::vector> DB::TabSeparatedFormatReader::readRowImpl() @ 0x000000003b6a8138 7. ./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.h:69: DB::TabSeparatedFormatReader::readRowForHeaderDetection() @ 0x000000003b6a6f8e 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000003b0a4b19 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b0a2454 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038761 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 14. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b3a4185 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b39f4e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3a6fbc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:14.598739 [ 16279 ] {c70eec01-5729-4301-bbee-552f4cad9d5c} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(18, 4) from String, because value is too short: In scope SELECT toDecimal64('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal64 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0e581 6. ./src/IO/readDecimalText.h:0: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032507731 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 9. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 10. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:14.599998 [ 16279 ] {c70eec01-5729-4301-bbee-552f4cad9d5c} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(18, 4) from String, because value is too short: In scope SELECT toDecimal64('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0e581 6. ./src/IO/readDecimalText.h:0: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032507731 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 9. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 10. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:14.614989 [ 16279 ] {f4823bc6-3e61-4091-988c-92a95524f3de} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal64 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:14.616019 [ 16279 ] {f4823bc6-3e61-4091-988c-92a95524f3de} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:14.629750 [ 16279 ] {275546f9-3fde-4a0a-a7b6-d4d9f81f8977} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal64 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:14.630752 [ 16279 ] {275546f9-3fde-4a0a-a7b6-d4d9f81f8977} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:14.644380 [ 16279 ] {adc862eb-c762-4d72-a977-129e74c3fdaf} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal64 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:14.645384 [ 16279 ] {adc862eb-c762-4d72-a977-129e74c3fdaf} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:14.659527 [ 16279 ] {3308e347-ea88-4cf4-8cfd-303a430e855c} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\'', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal64 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:14.660552 [ 16279 ] {3308e347-ea88-4cf4-8cfd-303a430e855c} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009267226 5. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 6. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:15.529722 [ 16279 ] {bbae3f31-3c79-4391-82c0-b4e9f5b7f047} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('x123', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal128 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:15.531027 [ 16279 ] {bbae3f31-3c79-4391-82c0-b4e9f5b7f047} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.275157 [ 16279 ] {4e62a103-4054-4db3-bd70-6af37fdcf999} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(38, 4) from String, because value is too short: In scope SELECT toDecimal128('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal128 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a0fc1c 6. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000003250894f 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 9. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 10. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:16.276497 [ 16279 ] {4e62a103-4054-4db3-bd70-6af37fdcf999} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(38, 4) from String, because value is too short: In scope SELECT toDecimal128('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a0fc1c 6. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000003250894f 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 9. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 10. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:16.292228 [ 16279 ] {4ff9e674-d982-41ad-b489-abe7b75ba1ae} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal128 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.293370 [ 16279 ] {4ff9e674-d982-41ad-b489-abe7b75ba1ae} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.294276 [ 16260 ] {800ec01a-4995-479b-aabe-93ec555758e4} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_67s27j5p.test_constraints (6a07fc3c-742b-4b5b-a0ac-d370e29c755b) is violated at row 1. Expression: (b > 10). Column values: b = 2. (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33894) (comment: 00952_basic_constraints.sh) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:16.296298 [ 16260 ] {800ec01a-4995-479b-aabe-93ec555758e4} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_67s27j5p.test_constraints (6a07fc3c-742b-4b5b-a0ac-d370e29c755b) is violated at row 1. Expression: (b > 10). Column values: b = 2. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:16.308304 [ 16279 ] {73434baf-7a1e-47e5-b8ad-7a7d95401ecf} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal128 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.309362 [ 16279 ] {73434baf-7a1e-47e5-b8ad-7a7d95401ecf} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.323625 [ 16279 ] {3f70e438-4080-481d-96e2-02054434a281} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal128 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.324854 [ 16279 ] {3f70e438-4080-481d-96e2-02054434a281} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.338418 [ 16279 ] {2ec73f6e-73a0-4d5f-845d-50bf9acd1ff5} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\'', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal128 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:16.339402 [ 16279 ] {2ec73f6e-73a0-4d5f-845d-50bf9acd1ff5} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bcb8a 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:17.227450 [ 16279 ] {c4cd22cc-60ea-47a7-9988-309871ffd82f} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('x123', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal256 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:17.229131 [ 16279 ] {c4cd22cc-60ea-47a7-9988-309871ffd82f} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:17.562748 [ 1587 ] {05ebcd2c-7cf1-46af-bace-6364c0b316cd} executeQuery: Code: 469. DB::Exception: Constraint `a_constraint` for table test_67s27j5p.test_constraints (6a07fc3c-742b-4b5b-a0ac-d370e29c755b) is violated at row 2. Expression: (a < 10). Column values: a = 10. (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33960) (comment: 00952_basic_constraints.sh) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:17.564788 [ 1587 ] {05ebcd2c-7cf1-46af-bace-6364c0b316cd} TCPHandler: Code: 469. DB::Exception: Constraint `a_constraint` for table test_67s27j5p.test_constraints (6a07fc3c-742b-4b5b-a0ac-d370e29c755b) is violated at row 2. Expression: (a < 10). Column values: a = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:17.996560 [ 16279 ] {1e140813-5a54-48c9-9382-81c5f3789a0e} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(76, 4) from String, because value is too short: In scope SELECT toDecimal256('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal256 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a1117c 6. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032509e33 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:0: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003269565e 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009310b59 9. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 10. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:17.997878 [ 16279 ] {1e140813-5a54-48c9-9382-81c5f3789a0e} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(76, 4) from String, because value is too short: In scope SELECT toDecimal256('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000201ffd0c 5. ./src/IO/readDecimalText.h:124: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a1117c 6. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032509e33 7. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:0: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003269565e 8. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009310b59 9. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 10. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:11:18.012968 [ 16279 ] {5c17cd14-408d-4fb9-83ce-d147506110e6} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal256 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:18.013991 [ 16279 ] {5c17cd14-408d-4fb9-83ce-d147506110e6} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:18.027734 [ 16279 ] {f23b3adc-8dae-4ad4-b02b-dba881284ceb} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal256 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:18.028762 [ 16279 ] {f23b3adc-8dae-4ad4-b02b-dba881284ceb} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:18.042264 [ 16279 ] {d79f7a29-cf4f-479e-aff6-603a121985d8} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal256 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:18.043264 [ 16279 ] {d79f7a29-cf4f-479e-aff6-603a121985d8} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:18.057168 [ 16279 ] {4468b947-abdf-4a3f-afc2-9f76d376ab4c} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\'', 4). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50116) (comment: 00700_to_decimal_or_something_1.gen.sql) (in query: SELECT toDecimal256 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:18.058170 [ 16279 ] {4468b947-abdf-4a3f-afc2-9f76d376ab4c} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal256, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000093111aa 5. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092fe367 6. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal256, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000092c4f9f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:20.103943 [ 1587 ] {0c950b98-ff07-4f99-9af1-9eb81cbfe03a} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34058) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:20.105244 [ 1587 ] {0c950b98-ff07-4f99-9af1-9eb81cbfe03a} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:23.255195 [ 16278 ] {8e8af764-864a-4115-b87a-a45b4bf15356} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:23.256376 [ 16278 ] {8e8af764-864a-4115-b87a-a45b4bf15356} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:24.034198 [ 16278 ] {726559f6-f1c3-4296-ad9c-5ec0bada3d85} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.035324 [ 16278 ] {726559f6-f1c3-4296-ad9c-5ec0bada3d85} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.050737 [ 16278 ] {6cae9d47-30f0-47c0-b272-286139be618d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.051784 [ 16278 ] {6cae9d47-30f0-47c0-b272-286139be618d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.067045 [ 16278 ] {091f91a9-257f-40f0-b165-0c10163285b6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.068092 [ 16278 ] {091f91a9-257f-40f0-b165-0c10163285b6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.083921 [ 16278 ] {bbb6482f-2b32-43bf-a55d-74317ccb87c3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.084957 [ 16278 ] {bbb6482f-2b32-43bf-a55d-74317ccb87c3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.098052 [ 16278 ] {5df5e687-5d7a-45e0-b493-3c6be77ae75b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.099005 [ 16278 ] {5df5e687-5d7a-45e0-b493-3c6be77ae75b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:24.111604 [ 16278 ] {1d7764bb-687d-4d5c-a2bc-9eb4d206d364} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(2023, 09, 11);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:24.112536 [ 16278 ] {1d7764bb-687d-4d5c-a2bc-9eb4d206d364} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:24.125765 [ 16278 ] {020654e2-8fd4-480b-877d-ef21045520e1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(2023, 110);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:24.126818 [ 16278 ] {020654e2-8fd4-480b-877d-ef21045520e1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa22c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:25.278003 [ 610 ] {e26033ab-b027-4673-a98f-6e1fe375b7cc} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45606) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=File(UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/StorageFile.cpp:1075: DB::StorageFile::StorageFile(DB::StorageFile::CommonArguments) @ 0x0000000038309995 6. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x0000000038312609 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x00000000383681f3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000383500f1 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:25.279202 [ 610 ] {e26033ab-b027-4673-a98f-6e1fe375b7cc} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/StorageFile.cpp:1075: DB::StorageFile::StorageFile(DB::StorageFile::CommonArguments) @ 0x0000000038309995 6. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x0000000038312609 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x00000000383681f3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000383500f1 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:25.338684 [ 16278 ] {5dd55453-5551-437b-b5b1-6ab70c4ee7e2} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(nan). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa1b7b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:25.339904 [ 16278 ] {5dd55453-5551-437b-b5b1-6ab70c4ee7e2} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa1b7b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:25.354301 [ 16278 ] {3e3ed53d-8ea3-47cd-922d-dc65f4987b87} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(inf). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa1b7b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:25.355391 [ 16278 ] {3e3ed53d-8ea3-47cd-922d-dc65f4987b87} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa1b7b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:25.370732 [ 16278 ] {81fe227e-cba1-41c1-8d6c-c1cbf09bbeb4} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(-inf). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa1b7b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:25.372106 [ 16278 ] {81fe227e-cba1-41c1-8d6c-c1cbf09bbeb4} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa1b7b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:25.960258 [ 610 ] {ffc68804-7fdf-42a8-8871-a1a27985a011} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45606) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=URL('http://some/url', UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c60408 6. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7bf3c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca7c1b 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca7849 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038c98734 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:25.961602 [ 610 ] {ffc68804-7fdf-42a8-8871-a1a27985a011} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c60408 6. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7bf3c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca7c1b 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca7849 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038c98734 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:26.452142 [ 610 ] {8a379469-031d-4e5a-8823-e80af034dc5a} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45606) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=S3('http://host:2020/test/data', UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:498: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0c08 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003927619a 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000392787b4 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:26.453364 [ 610 ] {8a379469-031d-4e5a-8823-e80af034dc5a} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:498: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0c08 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003927619a 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000392787b4 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:26.796258 [ 16278 ] {5503e78d-204e-42a3-bd69-42746db6cbdd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate32(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.797446 [ 16278 ] {5503e78d-204e-42a3-bd69-42746db6cbdd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate32(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.812419 [ 16278 ] {208f05d6-6eec-4607-ad29-f1a7c8056a5a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate32(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.813437 [ 16278 ] {208f05d6-6eec-4607-ad29-f1a7c8056a5a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate32(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.826334 [ 16278 ] {df78dd12-6eb5-4cdf-804a-abed2769ba59} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate32(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.827306 [ 16278 ] {df78dd12-6eb5-4cdf-804a-abed2769ba59} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate32(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.841000 [ 16278 ] {4d2ccd83-9e0f-4a29-9ed8-4613f13de840} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate32(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.841989 [ 16278 ] {4d2ccd83-9e0f-4a29-9ed8-4613f13de840} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate32(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.853744 [ 16278 ] {220459fb-44f8-47b3-9fe7-c16f674a3ad7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate32('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.854667 [ 16278 ] {220459fb-44f8-47b3-9fe7-c16f674a3ad7} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate32('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:11:26.943021 [ 610 ] {0329c9d4-2617-4caa-89df-9ffd927e1d59} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45606) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=HDFS('http://hdfs:9000/data', UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:498: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0c08 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003927619a 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000039278d67 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:26.944506 [ 610 ] {0329c9d4-2617-4caa-89df-9ffd927e1d59} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac6f5b7 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:498: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0c08 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003927619a 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000039278d67 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:27.606580 [ 16278 ] {b6094bc3-d84b-4e09-b5b7-789aa79fff76} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(2023, 09, 11);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:27.607943 [ 16278 ] {b6094bc3-d84b-4e09-b5b7-789aa79fff76} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:27.622751 [ 16278 ] {063dfbc0-4602-4ffd-8555-4096b08be782} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate32(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(2023, 110);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:27.623811 [ 16278 ] {063dfbc0-4602-4ffd-8555-4096b08be782} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate32(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa46c8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:28.534016 [ 1391 ] {1b1c69de-c6c4-42e0-a1cd-dae57fce231d} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_ftbpzyo4.t_json_async_insert FORMAT JSONAsObject' with query id 24943c38-9c54-420f-9841-2b525a1fa5c7. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.06.18 11:11:28.818807 [ 16278 ] {23ae039a-ac54-4154-965b-598e7f54119d} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(nan). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa3f8e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:28.819985 [ 16278 ] {23ae039a-ac54-4154-965b-598e7f54119d} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa3f8e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:28.834743 [ 16278 ] {2c8b5cf7-c858-49af-8207-66cd251c403c} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(inf). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa3f8e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:28.836203 [ 16278 ] {2c8b5cf7-c858-49af-8207-66cd251c403c} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa3f8e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:28.851017 [ 16278 ] {5e100863-1fb7-4078-b66d-e06543c14c93} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(-inf). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45550) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa3f8e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:28.852107 [ 16278 ] {5e100863-1fb7-4078-b66d-e06543c14c93} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa3f8e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:29.111303 [ 16264 ] {24943c38-9c54-420f-9841-2b525a1fa5c7} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45730) (comment: 02421_new_type_json_async_insert.sh) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b82aa 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000003271b8e2 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003271cacd 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000003b218814 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:0: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b215898 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:29.112884 [ 16264 ] {24943c38-9c54-420f-9841-2b525a1fa5c7} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b82aa 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000003271b8e2 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003271cacd 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000003b218814 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:0: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b215898 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:29.887125 [ 610 ] {fe84bc34-085c-41a6-8344-94701daf5ad1} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45768) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:29.890397 [ 610 ] {fe84bc34-085c-41a6-8344-94701daf5ad1} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:30.519868 [ 610 ] {64952204-248b-40b7-b06d-55208dea9997} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45856) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:30.522127 [ 610 ] {64952204-248b-40b7-b06d-55208dea9997} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:31.148343 [ 1814 ] {5015825c-8f6f-41d8-950e-0707d6928c4a} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45898) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:31.150265 [ 1814 ] {5015825c-8f6f-41d8-950e-0707d6928c4a} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:31.461820 [ 1391 ] {84bb6569-16ee-4cc3-b542-c457522e1b8b} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_ftbpzyo4.t_json_async_insert FORMAT JSONAsObject' with query id 7d950dec-b39c-47a3-a01b-a33ea9c0c316. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.06.18 11:11:31.463346 [ 1814 ] {7d950dec-b39c-47a3-a01b-a33ea9c0c316} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45924) (comment: 02421_new_type_json_async_insert.sh) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b82aa 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000003271b8e2 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003271cacd 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000003b218814 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:0: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b215898 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:31.465254 [ 1814 ] {7d950dec-b39c-47a3-a01b-a33ea9c0c316} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b82aa 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000003271b8e2 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003271cacd 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000003b218814 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:0: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b215898 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:31.791336 [ 1814 ] {4d7153d6-c9bd-4f71-9fda-909c7c4fe926} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38376) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(1e300);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:31.793469 [ 1814 ] {4d7153d6-c9bd-4f71-9fda-909c7c4fe926} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:32.426469 [ 1534 ] {a6db74fc-a17e-4340-a9a0-330096fe8b80} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38428) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-123.456);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:32.428532 [ 1534 ] {a6db74fc-a17e-4340-a9a0-330096fe8b80} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:33.070498 [ 16279 ] {ef3b3c96-81ed-4ed0-8348-1e45a8854a41} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38452) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:33.072887 [ 16279 ] {ef3b3c96-81ed-4ed0-8348-1e45a8854a41} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bc040c5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:11:37.272707 [ 1590 ] {97701f18-681e-4ed8-b6cc-18ee4c6d1f61} executeQuery: Code: 215. DB::Exception: Column c is not under aggregate function and not in GROUP BY keys. In query SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer = 1. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38672) (comment: 02701_invalid_having_NOT_AN_AGGREGATE.sql) (in query: SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer=1 -- { serverError NOT_AN_AGGREGATE } ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033586f3f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:37.274308 [ 1590 ] {97701f18-681e-4ed8-b6cc-18ee4c6d1f61} TCPHandler: Code: 215. DB::Exception: Column c is not under aggregate function and not in GROUP BY keys. In query SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer = 1. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033586f3f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:39.303143 [ 1587 ] {fa7aebec-6a38-46de-9fdb-56f3d3fe70c4} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017,'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38766) (comment: 02457_parse_date_time_best_effort.sql) (in query: select parseDateTimeBestEffort('01/12/2017,');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x00000000202245ce 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x0000000009523443 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:39.304818 [ 1587 ] {fa7aebec-6a38-46de-9fdb-56f3d3fe70c4} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017,'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x00000000202245ce 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x0000000009523443 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:40.058947 [ 1587 ] {144a1de6-bf3a-43fe-b212-62083174223b} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38766) (comment: 02457_parse_date_time_best_effort.sql) (in query: select parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffortUS(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000002022ce43 5. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000953d42e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:11:40.060167 [ 1587 ] {144a1de6-bf3a-43fe-b212-62083174223b} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffortUS(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000002022ce43 5. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000953d42e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:11:40.831434 [ 1587 ] {919aaff2-551c-4b07-8625-4f87b90adbf7} executeQuery: Code: 6. DB::Exception: Cannot parse string '18:31:44, 31/12/2015,' as DateTime: syntax error at position 20 (parsed just '18:31:44, 31/12/2015'): In scope SELECT parseDateTimeBestEffortUS('18:31:44, 31/12/2015,'). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38766) (comment: 02457_parse_date_time_best_effort.sql) (in query: select parseDateTimeBestEffortUS('18:31:44, 31/12/2015,');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000953f2bf 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:40.832845 [ 1587 ] {919aaff2-551c-4b07-8625-4f87b90adbf7} TCPHandler: Code: 6. DB::Exception: Cannot parse string '18:31:44, 31/12/2015,' as DateTime: syntax error at position 20 (parsed just '18:31:44, 31/12/2015'): In scope SELECT parseDateTimeBestEffortUS('18:31:44, 31/12/2015,'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000953f2bf 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:11:41.616993 [ 1587 ] {f7632b74-e2c5-4615-b950-376cc89bfb49} executeQuery: Code: 6. DB::Exception: Cannot parse string '01/12/2017, 18:31:44,' as DateTime: syntax error at position 20 (parsed just '01/12/2017, 18:31:44'): In scope SELECT parseDateTimeBestEffort('01/12/2017, 18:31:44,'). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38766) (comment: 02457_parse_date_time_best_effort.sql) (in query: select parseDateTimeBestEffort('01/12/2017, 18:31:44,');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x00000000095250bc 5. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:11:41.618214 [ 1587 ] {f7632b74-e2c5-4615-b950-376cc89bfb49} TCPHandler: Code: 6. DB::Exception: Cannot parse string '01/12/2017, 18:31:44,' as DateTime: syntax error at position 20 (parsed just '01/12/2017, 18:31:44'): In scope SELECT parseDateTimeBestEffort('01/12/2017, 18:31:44,'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x00000000095250bc 5. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:11:41.633127 [ 1587 ] {11b8e332-089d-403b-9bf9-3d72702ab4e9} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017, ,,,18:31:44'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38766) (comment: 02457_parse_date_time_best_effort.sql) (in query: select parseDateTimeBestEffort('01/12/2017, ,,,18:31:44');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x00000000202245ce 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x0000000009523443 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:41.634625 [ 1587 ] {11b8e332-089d-403b-9bf9-3d72702ab4e9} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017, ,,,18:31:44'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x00000000202245ce 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x0000000009523443 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:41.648690 [ 1587 ] {c405f177-896f-4e35-981b-5351a0491052} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38766) (comment: 02457_parse_date_time_best_effort.sql) (in query: select parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x00000000202245ce 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x0000000009523443 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:41.649707 [ 1587 ] {c405f177-896f-4e35-981b-5351a0491052} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x00000000202245ce 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x0000000009523443 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000951bbda 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:11:44.032579 [ 610 ] {849c5bfb-f55f-47e1-b837-ce53c4583b83} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual arrayJoin([1, 2]). In scope SELECT * FROM system.numbers LIMIT arrayJoin([1, 2]). (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45984) (comment: 01165_lost_part_empty_partition.sql) (in query: insert into rmt1(n) select * from system.numbers limit arrayJoin([1, 2]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9bd23 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:44.035709 [ 610 ] {849c5bfb-f55f-47e1-b837-ce53c4583b83} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual arrayJoin([1, 2]). In scope SELECT * FROM system.numbers LIMIT arrayJoin([1, 2]). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9bd23 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:11:44.911359 [ 16275 ] {} InterserverIOHTTPHandler: Code: 221. DB::Exception: No interserver IO endpoint named DataPartsExchange:default:/test/01165/test_ia8eppc1/rmt/replicas/1. (NO_SUCH_INTERSERVER_IO_ENDPOINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./src/Interpreters/InterserverIOHandler.h:80: DB::InterserverIOHandler::getEndpoint(String const&) const @ 0x000000003aa59708 5. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:63: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::InterserverIOHTTPHandler::Output&) @ 0x000000003aa52d8d 6. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:130: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa54db7 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:46.977112 [ 1274 ] {} test_ia8eppc1.rmt2 (f77b3403-7d17-448c-83eb-bc3969f7c356): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=20250617_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 221. DB::Exception: No interserver IO endpoint named DataPartsExchange:default:/test/01165/test_ia8eppc1/rmt/replicas/1. (NO_SUCH_INTERSERVER_IO_ENDPOINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./src/Interpreters/InterserverIOHandler.h:80: DB::InterserverIOHandler::getEndpoint(String const&) const @ 0x000000003aa59708 5. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:63: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::InterserverIOHTTPHandler::Output&) @ 0x000000003aa52d8d 6. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:130: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa54db7 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:47.006552 [ 698 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 20250617_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.18 11:11:47.043825 [ 698 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): Part 20250617_0_0_0 is lost forever. 2025.06.18 11:11:50.211714 [ 1264 ] {} test_ia8eppc1.rmt2 (d92f3768-6ee5-4893-9abe-510593eaecb5): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:50.265094 [ 1085 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering all_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.18 11:11:50.374072 [ 1085 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): Part all_0_0_0 is lost forever. 2025.06.18 11:11:54.049143 [ 1271 ] {} test_ia8eppc1.rmt2 (c3e11341-7925-4521-8589-ffcfbfcb5d1a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=16-836848764-20250617-1750227113_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:54.253017 [ 1265 ] {} test_ia8eppc1.rmt2 (c3e11341-7925-4521-8589-ffcfbfcb5d1a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=174-1284945639-20250617-1750227114_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:54.259069 [ 1269 ] {} test_ia8eppc1.rmt2 (c3e11341-7925-4521-8589-ffcfbfcb5d1a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=16-836848764-20250617-1750227113_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:54.319739 [ 1279 ] {} test_ia8eppc1.rmt2 (c3e11341-7925-4521-8589-ffcfbfcb5d1a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=16-836848764-20250617-1750227113_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:54.321416 [ 1274 ] {} test_ia8eppc1.rmt2 (c3e11341-7925-4521-8589-ffcfbfcb5d1a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=70--756464221-20250617-1750227114_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:54.321634 [ 1272 ] {} test_ia8eppc1.rmt2 (c3e11341-7925-4521-8589-ffcfbfcb5d1a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_ia8eppc1%2Frmt%2Freplicas%2F1&part=174-1284945639-20250617-1750227114_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:11:54.368582 [ 877 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 16-836848764-20250617-1750227113_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.18 11:11:54.392158 [ 877 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): Part 16-836848764-20250617-1750227113_0_0_0 is lost forever. 2025.06.18 11:11:54.393977 [ 877 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 70--756464221-20250617-1750227114_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.18 11:11:54.421830 [ 877 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): Part 70--756464221-20250617-1750227114_0_0_0 is lost forever. 2025.06.18 11:11:54.423845 [ 877 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 174-1284945639-20250617-1750227114_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.18 11:11:54.445286 [ 877 ] {} test_ia8eppc1.rmt2 (ReplicatedMergeTreePartCheckThread): Part 174-1284945639-20250617-1750227114_0_0_0 is lost forever. 2025.06.18 11:12:08.697292 [ 1814 ] {cb0dd728-f16c-48a7-a36b-972d65ab25fe} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.698624 [ 1814 ] {cb0dd728-f16c-48a7-a36b-972d65ab25fe} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.718784 [ 1814 ] {80118e8e-dec5-4f07-884b-82acec12e39b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.720007 [ 1814 ] {80118e8e-dec5-4f07-884b-82acec12e39b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.739013 [ 1814 ] {1a99c7d4-c624-4841-80be-645d8f71b894} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.750716 [ 1814 ] {1a99c7d4-c624-4841-80be-645d8f71b894} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.772768 [ 1814 ] {d6bb8d8a-d7e4-4d81-84fa-3e5b86d90aa9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.774221 [ 1814 ] {d6bb8d8a-d7e4-4d81-84fa-3e5b86d90aa9} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.791617 [ 1814 ] {7931b06b-45dd-4727-b3cd-574a9c9e7031} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.792918 [ 1814 ] {7931b06b-45dd-4727-b3cd-574a9c9e7031} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.816021 [ 1814 ] {0720d5a9-ad30-47bd-8ff4-5a6414f706d6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.817768 [ 1814 ] {0720d5a9-ad30-47bd-8ff4-5a6414f706d6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.839677 [ 1814 ] {fe95e6b6-a473-42ba-98b0-cd5392ce1f05} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.841044 [ 1814 ] {fe95e6b6-a473-42ba-98b0-cd5392ce1f05} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.859072 [ 1814 ] {9f10f57b-a964-4356-93fd-eb795b28d771} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.861978 [ 1814 ] {9f10f57b-a964-4356-93fd-eb795b28d771} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.878213 [ 1814 ] {25647c1d-d204-48ae-933b-98c2e0a68d8e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate('1980', '10');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.879774 [ 1814 ] {25647c1d-d204-48ae-933b-98c2e0a68d8e} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.894046 [ 1814 ] {322d8b1f-fb39-423f-a6bf-75290270b61f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate('-1980', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.897104 [ 1814 ] {322d8b1f-fb39-423f-a6bf-75290270b61f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.911404 [ 1814 ] {dc8bcdee-8587-4eb0-bd78-469b52d11a28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate('aa', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.912506 [ 1814 ] {dc8bcdee-8587-4eb0-bd78-469b52d11a28} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.925125 [ 1814 ] {541c07bc-15d7-4b10-94e6-4bc0bf191d45} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57930) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(1994, 'aa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:08.926195 [ 1814 ] {541c07bc-15d7-4b10-94e6-4bc0bf191d45} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f94676 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:09.660923 [ 3040 ] {d6ed26d6-5b94-4daa-a2db-56cec4dc18f3} DistributedSink: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 1)), implicit conversion will be done. 2025.06.18 11:12:09.714864 [ 2417 ] {d6ed26d6-5b94-4daa-a2db-56cec4dc18f3} DistributedSink: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 1)), implicit conversion will be done. 2025.06.18 11:12:09.890926 [ 3096 ] {01d36067-e141-498d-af82-2db61ef77583} test_tqsmntlt.dist_01683.DistributedInsertQueue.default: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 0)), implicit conversion will be done 2025.06.18 11:12:09.891552 [ 2957 ] {01d36067-e141-498d-af82-2db61ef77583} test_tqsmntlt.dist_01683.DistributedInsertQueue.default: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 0)), implicit conversion will be done 2025.06.18 11:12:11.051460 [ 1588 ] {e816158b-57a0-4c36-a231-a669d9bf2985} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType() FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58128) (comment: 02981_variant_type_function.sql) (in query: SELECT variantType() FROM test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.053704 [ 1588 ] {e816158b-57a0-4c36-a231-a669d9bf2985} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType() FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.077070 [ 1588 ] {a9c26afe-13d7-4a86-8d94-7d61408532db} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(v, v) FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58128) (comment: 02981_variant_type_function.sql) (in query: SELECT variantType(v, v) FROM test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.078709 [ 1588 ] {a9c26afe-13d7-4a86-8d94-7d61408532db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(v, v) FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.220518 [ 1828 ] {5459f1b9-a472-45a0-94be-c84b48e4b015} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test add column bad Variant(UInt32, String);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:86: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c345 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.222593 [ 1828 ] {5459f1b9-a472-45a0-94be-c84b48e4b015} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:86: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c345 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.395618 [ 1583 ] {e0564e3c-88de-4b27-98f9-3230f5fafbb4} executeQuery: Code: 47. DB::Exception: Missing columns: 'test_01103.t1_distr.id' while processing query: '_CAST(now(([NULL, NULL, NULL, [-2147483648], [NULL, NULL, NULL, NULL, NULL, NULL, NULL]] AND (1048576 AND NULL) AND (NULL AND 1048575 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id)) AS b_tmp_alter16487079280528285666, 'DateTime') AS b, b_tmp_alter16487079280528285666', required columns: 'test_01103.t1_distr.id' 'test_01103.t1_distr.id': default expression and column type are incompatible. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58170) (comment: 02041_test_fuzzy_alter.sql) (in query: ALTER TABLE alter_table MODIFY COLUMN `b` DateTime DEFAULT now(([NULL, NULL, NULL, [-2147483648], [NULL, NULL, NULL, NULL, NULL, NULL, NULL]] AND (1048576 AND NULL) AND (NULL AND 1048575 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 6. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.397123 [ 1583 ] {e0564e3c-88de-4b27-98f9-3230f5fafbb4} TCPHandler: Code: 47. DB::Exception: Missing columns: 'test_01103.t1_distr.id' while processing query: '_CAST(now(([NULL, NULL, NULL, [-2147483648], [NULL, NULL, NULL, NULL, NULL, NULL, NULL]] AND (1048576 AND NULL) AND (NULL AND 1048575 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id)) AS b_tmp_alter16487079280528285666, 'DateTime') AS b, b_tmp_alter16487079280528285666', required columns: 'test_01103.t1_distr.id' 'test_01103.t1_distr.id': default expression and column type are incompatible. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 6. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.626518 [ 1828 ] {a5729afc-e5d8-4b51-bbd4-43beaa8d09b6} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because experimental Dynamic type is not allowed. Set setting allow_experimental_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test add column bad Dynamic;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:130: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c442 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.627723 [ 1828 ] {a5729afc-e5d8-4b51-bbd4-43beaa8d09b6} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because experimental Dynamic type is not allowed. Set setting allow_experimental_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:130: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c442 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:11.849590 [ 1588 ] {636a2b78-ce09-4ce9-b1f7-a8817ff180da} executeQuery: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Nullable(String) instead: In scope SELECT variantType(v.String) FROM test. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58128) (comment: 02981_variant_type_function.sql) (in query: SELECT variantType(v.String) FROM test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionVariantType::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c974296 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:12:11.851182 [ 1588 ] {636a2b78-ce09-4ce9-b1f7-a8817ff180da} TCPHandler: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Nullable(String) instead: In scope SELECT variantType(v.String) FROM test. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionVariantType::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c974296 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:12:12.020372 [ 1828 ] {32461808-7f82-4359-b167-1ca8a370265b} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test add column bad LowCardinality(UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:48: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c677 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:12.021656 [ 1828 ] {32461808-7f82-4359-b167-1ca8a370265b} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:48: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c677 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:12.399116 [ 1828 ] {28f77d7b-bcfc-46c9-9fc2-a9c05f2d805e} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test add column bad FixedString(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000359a066d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c57f 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:12.400337 [ 1828 ] {28f77d7b-bcfc-46c9-9fc2-a9c05f2d805e} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000359a066d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c57f 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099207 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:12.793933 [ 1828 ] {3f955f30-d99f-4d17-bbb4-90fbb381d385} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test modify column id Variant(UInt32, String);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:86: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c345 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:12.795275 [ 1828 ] {3f955f30-d99f-4d17-bbb4-90fbb381d385} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:86: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c345 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:13.191360 [ 1828 ] {df4cf64d-09dc-438f-a05c-a8730bcd44c4} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because experimental Dynamic type is not allowed. Set setting allow_experimental_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test modify column id Dynamic;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:130: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c442 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:13.195828 [ 1828 ] {df4cf64d-09dc-438f-a05c-a8730bcd44c4} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because experimental Dynamic type is not allowed. Set setting allow_experimental_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:130: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c442 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:13.626948 [ 1828 ] {d703d9cf-0255-437e-a828-70e555ac0706} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test modify column id LowCardinality(UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:48: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c677 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:13.628811 [ 1828 ] {d703d9cf-0255-437e-a828-70e555ac0706} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:48: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c677 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:13.731679 [ 612 ] {526942ce-816e-40c5-8ac9-1ba213b5a9a7} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt32: In scope SELECT accurateCast(1e35, 'UInt32'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e35, 'UInt32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x000000000887aa66 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000008858b09 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:13.733078 [ 612 ] {526942ce-816e-40c5-8ac9-1ba213b5a9a7} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt32: In scope SELECT accurateCast(1e35, 'UInt32'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x000000000887aa66 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000008858b09 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:14.010736 [ 1828 ] {3ed50c32-4932-4e98-8349-1ada94a7501b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58168) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (in query: alter table test modify column id FixedString(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000359a066d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c57f 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:14.012238 [ 1828 ] {3ed50c32-4932-4e98-8349-1ada94a7501b} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000359a066d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c57f 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599951b 6. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038099a0f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:14.533398 [ 612 ] {6ee55558-fa14-4cb2-b096-1814425785d9} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt64: In scope SELECT accurateCast(1e35, 'UInt64'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e35, 'UInt64');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000088d37d0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000088b2109 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:14.534694 [ 612 ] {6ee55558-fa14-4cb2-b096-1814425785d9} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt64: In scope SELECT accurateCast(1e35, 'UInt64'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000088d37d0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000088b2109 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:15.361340 [ 612 ] {153066d2-9db9-41f3-a648-8cfd2eb766a9} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt128: In scope SELECT accurateCast(1e35, 'UInt128'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e35, 'UInt128');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000892b0af 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000890a349 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:15.378611 [ 612 ] {153066d2-9db9-41f3-a648-8cfd2eb766a9} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt128: In scope SELECT accurateCast(1e35, 'UInt128'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000892b0af 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000890a349 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.180784 [ 612 ] {58ab23c7-e156-48b4-9e15-223b94a7c45b} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt256: In scope SELECT accurateCast(1e35, 'UInt256'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e35, 'UInt256');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000897ee91 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000895dee9 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.182053 [ 612 ] {58ab23c7-e156-48b4-9e15-223b94a7c45b} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt256: In scope SELECT accurateCast(1e35, 'UInt256'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000897ee91 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000895dee9 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.423895 [ 612 ] {c5b5951d-1958-4a8a-a30a-75efd1661d9f} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt64: In scope SELECT accurateCast(100000000000000000000., 'UInt64'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e20, 'UInt64');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000088d37d0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000088b2109 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.425111 [ 612 ] {c5b5951d-1958-4a8a-a30a-75efd1661d9f} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt64: In scope SELECT accurateCast(100000000000000000000., 'UInt64'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000088d37d0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000088b2109 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.438533 [ 612 ] {8c26989d-13dc-484c-af49-5e5b5128ec55} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt128: In scope SELECT accurateCast(100000000000000000000., 'UInt128'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e20, 'UInt128');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000892b0af 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000890a349 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.439737 [ 612 ] {8c26989d-13dc-484c-af49-5e5b5128ec55} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt128: In scope SELECT accurateCast(100000000000000000000., 'UInt128'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000892b0af 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000890a349 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.453322 [ 612 ] {ba01429d-74bd-477a-848d-3a622336fa04} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt256: In scope SELECT accurateCast(100000000000000000000., 'UInt256'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e20, 'UInt256');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000897ee91 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000895dee9 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.457756 [ 612 ] {ba01429d-74bd-477a-848d-3a622336fa04} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type UInt256: In scope SELECT accurateCast(100000000000000000000., 'UInt256'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000000897ee91 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000895dee9 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:16.585993 [ 610 ] {a9527907-b993-4b4f-b9df-9e9e4bb12226} executeQuery: Code: 43. DB::Exception: Second argument (weight) for function quantileExactWeighted must be unsigned integer, but it has type Float64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57106) (comment: 00831_quantile_weighted_parameter_check.sql) (in query: SELECT quantileExactWeighted(0.5)(number, 0.1) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. ./src/AggregateFunctions/AggregateFunctionQuantile.h:98: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002bb9f095 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:16.587650 [ 610 ] {a9527907-b993-4b4f-b9df-9e9e4bb12226} TCPHandler: Code: 43. DB::Exception: Second argument (weight) for function quantileExactWeighted must be unsigned integer, but it has type Float64. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. ./src/AggregateFunctions/AggregateFunctionQuantile.h:98: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002bb9f095 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.239210 [ 612 ] {aaf0cbb8-5977-43cd-b527-3d10f88b4ea0} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type Int64: In scope SELECT accurateCast(10000000000000000000., 'Int64'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56962) (comment: 01906_bigint_accurate_cast_ubsan.sql) (in query: SELECT accurateCast(1e19, 'Int64');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x0000000008ad84e4 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000008ab69c9 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:17.240541 [ 612 ] {aaf0cbb8-5977-43cd-b527-3d10f88b4ea0} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type Int64: In scope SELECT accurateCast(10000000000000000000., 'Int64'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x0000000008ad84e4 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000008ab69c9 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:17.766501 [ 16278 ] {8e00ba51-61c1-49ae-80d3-b80f6147afc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT * FROM t1 INNER JOIN t2 ON isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56952) (comment: 02861_join_on_nullsafe_compare.gen.sql) (in query: -- check illegal queries SELECT * FROM t1 JOIN t2 ON isNotDistinctFrom();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.768026 [ 16278 ] {8e00ba51-61c1-49ae-80d3-b80f6147afc6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT * FROM t1 INNER JOIN t2 ON isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.788094 [ 16278 ] {e58b438f-1285-430b-96db-6f7e0f5c9067} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT * FROM t1 INNER JOIN t2 ON isNotDistinctFrom(t1.a). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56952) (comment: 02861_join_on_nullsafe_compare.gen.sql) (in query: SELECT * FROM t1 JOIN t2 ON isNotDistinctFrom(t1.a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.789387 [ 16278 ] {e58b438f-1285-430b-96db-6f7e0f5c9067} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT * FROM t1 INNER JOIN t2 ON isNotDistinctFrom(t1.a). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.809806 [ 16278 ] {da4591d7-4026-4c45-96f4-dcd61b7fdd8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT * FROM t1 INNER JOIN t2 ON isNotDistinctFrom(t1.a, t2.a, t2.b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56952) (comment: 02861_join_on_nullsafe_compare.gen.sql) (in query: SELECT * FROM t1 JOIN t2 ON isNotDistinctFrom(t1.a, t2.a, t2.b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.811141 [ 16278 ] {da4591d7-4026-4c45-96f4-dcd61b7fdd8f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT * FROM t1 INNER JOIN t2 ON isNotDistinctFrom(t1.a, t2.a, t2.b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.826136 [ 16278 ] {1f0d1932-fa18-4fa0-a6a9-1a28f510f6a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT isNotDistinctFrom(a) FROM t1. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56952) (comment: 02861_join_on_nullsafe_compare.gen.sql) (in query: SELECT isNotDistinctFrom(a) from t1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:17.827251 [ 16278 ] {1f0d1932-fa18-4fa0-a6a9-1a28f510f6a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT isNotDistinctFrom(a) FROM t1. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:18.463904 [ 16278 ] {a564cdbb-9a53-46bc-b0e8-137a8aba10a1} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56952) (comment: 02861_join_on_nullsafe_compare.gen.sql) (in query: SELECT isNotDistinctFrom(a, b) from t1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::FunctionIsNotDistinctFrom::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001406edf0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:18.465254 [ 16278 ] {a564cdbb-9a53-46bc-b0e8-137a8aba10a1} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::FunctionIsNotDistinctFrom::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001406edf0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:18.487828 [ 16278 ] {e5652c2a-5837-4f5f-82df-c22a62aad737} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56952) (comment: 02861_join_on_nullsafe_compare.gen.sql) (in query: SELECT a <=> b from t1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::FunctionIsNotDistinctFrom::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001406edf0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:18.489068 [ 16278 ] {e5652c2a-5837-4f5f-82df-c22a62aad737} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::FunctionIsNotDistinctFrom::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001406edf0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:18.510803 [ 16278 ] {81d2ea2f-a026-4640-8b99-850a368aca7a} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56952) (comment: 02861_join_on_nullsafe_compare.gen.sql) (in query: SELECT a IS NOT DISTINCT FROM b from t1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::FunctionIsNotDistinctFrom::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001406edf0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:18.512046 [ 16278 ] {81d2ea2f-a026-4640-8b99-850a368aca7a} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::FunctionIsNotDistinctFrom::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001406edf0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:20.898273 [ 1588 ] {7069dd05-cec5-4516-83d5-bb10c2b5e0e0} executeQuery: Code: 471. DB::Exception: Could not specify `disk` and `storage_policy` at the same time for storage Log Family. (INVALID_SETTING_VALUE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57326) (comment: 02554_log_faminy_support_storage_policy.sql) (in query: CREATE TABLE test_2554_error (n UInt32) ENGINE = Log SETTINGS disk = 'default', storage_policy = 'default';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageLogSettings.cpp:27: DB::getDiskName(DB::ASTStorage&, std::shared_ptr) @ 0x0000000038d863f3 5. ./build_docker/./src/Storages/StorageLog.cpp:1160: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038d6c35d 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:20.899708 [ 1588 ] {7069dd05-cec5-4516-83d5-bb10c2b5e0e0} TCPHandler: Code: 471. DB::Exception: Could not specify `disk` and `storage_policy` at the same time for storage Log Family. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageLogSettings.cpp:27: DB::getDiskName(DB::ASTStorage&, std::shared_ptr) @ 0x0000000038d863f3 5. ./build_docker/./src/Storages/StorageLog.cpp:1160: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038d6c35d 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:23.338401 [ 16279 ] {d4da56c5-a8b7-421c-8c1d-4caec283a302} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45618) (comment: 01246_extractAllGroupsVertical.sql) (in query: -- error cases SELECT extractAllGroupsVertical();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:23.339709 [ 16279 ] {d4da56c5-a8b7-421c-8c1d-4caec283a302} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:23.354812 [ 16279 ] {17ccdd2d-548b-4dd4-8f0d-b5119db18fa6} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsVertical('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45618) (comment: 01246_extractAllGroupsVertical.sql) (in query: SELECT extractAllGroupsVertical('hello');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:23.356159 [ 16279 ] {17ccdd2d-548b-4dd4-8f0d-b5119db18fa6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsVertical('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:23.376378 [ 1241 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:23.862972 [ 7729 ] {1f645d1c-2c13-4083-9304-ef4d4f1a5a52} executeQuery: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_b1es1yv1.collapsing_merge_tree (92dc6d2d-c5d7-4252-a64b-660114e5ef1d) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45662) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.sh) (in query: INSERT INTO collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:23.865475 [ 7729 ] {1f645d1c-2c13-4083-9304-ef4d4f1a5a52} TCPHandler: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_b1es1yv1.collapsing_merge_tree (92dc6d2d-c5d7-4252-a64b-660114e5ef1d) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:24.144308 [ 16279 ] {f74fa31f-c3a4-4776-ae1f-767d4cf61e86} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsVertical('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45618) (comment: 01246_extractAllGroupsVertical.sql) (in query: SELECT extractAllGroupsVertical('hello', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f94d76e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:24.145665 [ 16279 ] {f74fa31f-c3a4-4776-ae1f-767d4cf61e86} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsVertical('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f94d76e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:24.161265 [ 16279 ] {e5908c8a-1aae-4b87-a37d-7fb07954ea1b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsVertical(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45618) (comment: 01246_extractAllGroupsVertical.sql) (in query: SELECT extractAllGroupsVertical(123, 'world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f94d76e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:24.162449 [ 16279 ] {e5908c8a-1aae-4b87-a37d-7fb07954ea1b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsVertical(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f94d76e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:24.275860 [ 1241 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037434bf0 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037433e84 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003804c1e5 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bf806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec4a72 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:24.915125 [ 16279 ] {a8044672-a9f4-458b-83a9-efdeda77d127} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsVertical('hello world', '((('). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45618) (comment: 01246_extractAllGroupsVertical.sql) (in query: SELECT extractAllGroupsVertical('hello world', '(((');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000083b02cd 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000200aa178 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f94b215 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:24.916478 [ 16279 ] {a8044672-a9f4-458b-83a9-efdeda77d127} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsVertical('hello world', '((('). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000083b02cd 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000200aa178 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f94b215 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:24.935141 [ 16279 ] {e3cf7086-49b5-41a2-8fc8-12067babc9e3} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: String: In scope SELECT extractAllGroupsVertical('hello world', materialize('\\w+')). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45618) (comment: 01246_extractAllGroupsVertical.sql) (in query: SELECT extractAllGroupsVertical('hello world', materialize('\\w+'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f94d76e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:24.936489 [ 16279 ] {e3cf7086-49b5-41a2-8fc8-12067babc9e3} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: String: In scope SELECT extractAllGroupsVertical('hello world', materialize('\\w+')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f94d76e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:12:25.212120 [ 1248 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:25.214150 [ 1248 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037434bf0 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037433e84 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003804c1e5 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bf806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec4a72 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:25.549538 [ 1245 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:25.551581 [ 1245 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037434bf0 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037433e84 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003804c1e5 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bf806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec4a72 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:25.716901 [ 16279 ] {27f1cfde-6ae8-4e2c-b429-ccd9afa357c3} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsVertical('hello world', '\\w+'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45618) (comment: 01246_extractAllGroupsVertical.sql) (in query: SELECT extractAllGroupsVertical('hello world', '\\w+');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f94ccf8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:12:25.718125 [ 16279 ] {27f1cfde-6ae8-4e2c-b429-ccd9afa357c3} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsVertical('hello world', '\\w+'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f94ccf8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:12:26.299759 [ 1252 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:26.301824 [ 1252 ] {689aad88-666f-44a1-91fa-fe73097fb173::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037434bf0 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037433e84 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003804c1e5 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bf806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec4a72 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:27.799331 [ 1583 ] {10b1fcf3-80a6-4085-a409-a817f3c20945} executeQuery: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_b1es1yv1.versioned_collapsing_merge_tree (c4181492-2181-478b-8ed8-f87a2d67fb54) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45892) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.sh) (in query: INSERT INTO versioned_collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:27.801928 [ 1583 ] {10b1fcf3-80a6-4085-a409-a817f3c20945} TCPHandler: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_b1es1yv1.versioned_collapsing_merge_tree (c4181492-2181-478b-8ed8-f87a2d67fb54) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:29.651199 [ 610 ] {5371f3d7-566c-411e-8795-0abb03075480} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45962) (comment: 01416_clear_column_pk.sql) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key1 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3430: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039758604 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:29.652495 [ 610 ] {5371f3d7-566c-411e-8795-0abb03075480} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3430: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039758604 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:29.738461 [ 610 ] {777f508f-07bd-4c43-80e6-2c538c13fdb6} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45962) (comment: 01416_clear_column_pk.sql) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key2 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3430: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039758604 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:29.739702 [ 610 ] {777f508f-07bd-4c43-80e6-2c538c13fdb6} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3430: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039758604 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:31.706453 [ 1534 ] {56d117b6-b54d-42b7-beca-3df9e40a65d8} executeQuery: Code: 36. DB::Exception: Unexpected value of maximum unit argument (second) for function formatReadableTimeDelta, the only allowed values are: 'nanoseconds', 'microseconds', 'nanoseconds', 'seconds', 'minutes', 'hours', 'days', 'months', 'years'.: In scope SELECT formatReadableTimeDelta(-(((((1 + 60) + 3600) + 86400) + (30.5 * 86400)) + (365 * 86400)), 'second'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46040) (comment: 01521_format_readable_time_delta2.sql) (in query: SELECT formatReadableTimeDelta(-(1 + 60 + 3600 + 86400 + 30.5 * 86400 + 365 * 86400), 'second');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type>, String const&, std::basic_string_view> const&, String&&) @ 0x000000000fb080b7 4. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::dispatchUnit(std::basic_string_view> const&, DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::Unit, String const&) const @ 0x000000000fb06be9 5. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fb02a01 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:31.708058 [ 1534 ] {56d117b6-b54d-42b7-beca-3df9e40a65d8} TCPHandler: Code: 36. DB::Exception: Unexpected value of maximum unit argument (second) for function formatReadableTimeDelta, the only allowed values are: 'nanoseconds', 'microseconds', 'nanoseconds', 'seconds', 'minutes', 'hours', 'days', 'months', 'years'.: In scope SELECT formatReadableTimeDelta(-(((((1 + 60) + 3600) + 86400) + (30.5 * 86400)) + (365 * 86400)), 'second'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type>, String const&, std::basic_string_view> const&, String&&) @ 0x000000000fb080b7 4. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::dispatchUnit(std::basic_string_view> const&, DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::Unit, String const&) const @ 0x000000000fb06be9 5. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fb02a01 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:34.158702 [ 1534 ] {ca6a4380-7af5-4dc6-ae45-4d4bd8482d57} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45598) (comment: 01890_state_of_state.sql) (in query: SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d9dfff9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012f12cd6 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:12:34.160078 [ 1534 ] {ca6a4380-7af5-4dc6-ae45-4d4bd8482d57} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d9dfff9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012f12cd6 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:12:35.114180 [ 1534 ] {463c2df4-97ac-46db-82c1-9853ea164031} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45598) (comment: 01890_state_of_state.sql) (in query: SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x000000002cece3c3 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ce7a3a7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 11. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012f12cd6 12. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:12:35.115489 [ 1534 ] {463c2df4-97ac-46db-82c1-9853ea164031} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x000000002cece3c3 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ce7a3a7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 11. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012f12cd6 12. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:12:35.880591 [ 1534 ] {79482cf5-deeb-4ddb-ac10-e16d25bb9c82} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45598) (comment: 01890_state_of_state.sql) (in query: SELECT toTypeName(quantileState(x)) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b685fad 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:35.882072 [ 1534 ] {79482cf5-deeb-4ddb-ac10-e16d25bb9c82} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b685fad 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:36.558771 [ 1534 ] {e880ae7b-feed-4af8-a31b-5917ba8405fc} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45598) (comment: 01890_state_of_state.sql) (in query: SELECT hex(toString(quantileState(x))) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b685fad 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:12:36.560279 [ 1534 ] {e880ae7b-feed-4af8-a31b-5917ba8405fc} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b685fad 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de954 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:12:37.785444 [ 1590 ] {5812fc30-b12f-4bfc-917a-a98899be78ae} executeQuery: Code: 524. DB::Exception: Cannot ALTER column: Cannot apply mutation because it breaks projection p1. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45736) (comment: 02920_alter_column_of_projections.sql) (in query: -- Cannot ALTER, which breaks key column of projection. ALTER TABLE t MODIFY COLUMN age Nullable(Int32);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/AlterCommands.cpp:1226: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038093ade 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:37.786993 [ 1590 ] {5812fc30-b12f-4bfc-917a-a98899be78ae} TCPHandler: Code: 524. DB::Exception: Cannot ALTER column: Cannot apply mutation because it breaks projection p1. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/AlterCommands.cpp:1226: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038093ade 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:38.625544 [ 1590 ] {fab5e9d7-19c4-4e81-a541-9330a0e7ca15} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(uniq, Int16) to AggregateFunction(uniq, Int32) is not supported: While processing _CAST(`uniq(i)`, 'AggregateFunction(uniq, Int32)') AS `uniq(i)`: Cannot apply mutation because it breaks projection p1. (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45736) (comment: 02920_alter_column_of_projections.sql) (in query: -- Cannot ALTER, uniq(Int16) is not compatible with uniq(Int32). ALTER TABLE t MODIFY COLUMN i Int32;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x00000000087216d8 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086cb904 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000086c4c11 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321a587 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000332182ad 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 14. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 16. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:0: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000035905213 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000359039f9 18. ./contrib/llvm-project/libcxx/include/list:616: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000380922e1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:12:38.626977 [ 1590 ] {fab5e9d7-19c4-4e81-a541-9330a0e7ca15} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(uniq, Int16) to AggregateFunction(uniq, Int32) is not supported: While processing _CAST(`uniq(i)`, 'AggregateFunction(uniq, Int32)') AS `uniq(i)`: Cannot apply mutation because it breaks projection p1. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x00000000087216d8 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086cb904 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000086c4c11 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321a587 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000332182ad 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 14. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 16. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:0: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000035905213 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000359039f9 18. ./contrib/llvm-project/libcxx/include/list:616: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000380922e1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:12:41.559146 [ 610 ] {cdb55077-7a01-4149-97c8-3b81a89d67ff} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(ColumnLowCardinality): While executing RawBLOBRowOutputFormat. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53334) (comment: 02429_low_cardinality_trash.sh) (in query: SELECT rand64(1) % 10 AS k, groupArray(toString(64 - floor(log2(rand64(2) + 1))))::Array(LowCardinality(String)) FROM numbers(100) GROUP BY k FORMAT RawBLOB), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036fb7fd7 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b68469d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003aeda5e5 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::consume(DB::Chunk) @ 0x000000003aed9cce 8. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003aed5a3a 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:41.564711 [ 610 ] {cdb55077-7a01-4149-97c8-3b81a89d67ff} DynamicQueryHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(ColumnLowCardinality): While executing RawBLOBRowOutputFormat. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036fb7fd7 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b68469d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003aeda5e5 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::consume(DB::Chunk) @ 0x000000003aed9cce 8. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003aed5a3a 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:42.832226 [ 16264 ] {295f711d-a510-4c98-bb26-244247ff9e0f} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41496) (comment: 01093_cyclic_defaults_filimonov.sql) (in query: CREATE TABLE test ( `a0` UInt64 DEFAULT a1 + 1, `a1` UInt64 DEFAULT a0 + 1, `a2` UInt64 DEFAULT a3 + a4, `a3` UInt64 DEFAULT a2 + 1, `a4` UInt64 ALIAS a3 + 1 ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 19. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 23. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 24. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:42.833678 [ 16264 ] {295f711d-a510-4c98-bb26-244247ff9e0f} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 19. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 23. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 24. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:12:43.384687 [ 16264 ] {f5d61bdf-fdb6-43bd-8d57-30eff27fba48} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41496) (comment: 01093_cyclic_defaults_filimonov.sql) (in query: CREATE TABLE pythagoras ( `a` Float64 DEFAULT sqrt((c * c) - (b * b)), `b` Float64 DEFAULT sqrt((c * c) - (a * a)), `c` Float64 DEFAULT sqrt((a * a) + (b * b)) ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 27. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 31. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 2025.06.18 11:12:43.386424 [ 16264 ] {f5d61bdf-fdb6-43bd-8d57-30eff27fba48} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035735804 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035736f48 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737712 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b81a 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573b099 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035737725 27. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003563a980 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563fc4b 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ebd29 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 31. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 2025.06.18 11:12:43.411660 [ 610 ] {0cc33f45-6059-4aa4-8ddd-da905b2ed2d2} executeQuery: Code: 359. DB::Exception: Table or Partition in test_z3rytu0n.test_max_size_drop was not dropped. Reason: 1. Size (4.13 KB) is greater than max_[table/partition]_size_to_drop (1.00 B) 2. File '/var/lib/clickhouse/flags/force_drop_table' intended to force DROP doesn't exist How to fix this: 1. Either increase (or set to zero) max_[table/partition]_size_to_drop in server config 2. Either pass a bigger (or set to zero) max_[table/partition]_size_to_drop through query settings 3. Either create forcing file /var/lib/clickhouse/flags/force_drop_table and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/force_drop_table' && sudo chmod 666 '/var/lib/clickhouse/flags/force_drop_table'. (TABLE_SIZE_EXCEEDS_MAX_DROP_SIZE_LIMIT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41524) (comment: 02932_query_settings_max_size_drop.sql) (in query: DROP TABLE test_max_size_drop SETTINGS max_table_size_to_drop = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&, String&&, char const*&&, String&&, String&&, String&&) @ 0x00000000337be97c 4. ./build_docker/./src/Interpreters/Context.cpp:4638: DB::Context::checkCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x00000000337930cf 5. ./build_docker/./src/Interpreters/Context.cpp:4676: DB::Context::checkTableCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x0000000033793449 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000003a2d0651 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:294: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492c118 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:43.413234 [ 610 ] {0cc33f45-6059-4aa4-8ddd-da905b2ed2d2} TCPHandler: Code: 359. DB::Exception: Table or Partition in test_z3rytu0n.test_max_size_drop was not dropped. Reason: 1. Size (4.13 KB) is greater than max_[table/partition]_size_to_drop (1.00 B) 2. File '/var/lib/clickhouse/flags/force_drop_table' intended to force DROP doesn't exist How to fix this: 1. Either increase (or set to zero) max_[table/partition]_size_to_drop in server config 2. Either pass a bigger (or set to zero) max_[table/partition]_size_to_drop through query settings 3. Either create forcing file /var/lib/clickhouse/flags/force_drop_table and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/force_drop_table' && sudo chmod 666 '/var/lib/clickhouse/flags/force_drop_table'. (TABLE_SIZE_EXCEEDS_MAX_DROP_SIZE_LIMIT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&, String&&, char const*&&, String&&, String&&, String&&) @ 0x00000000337be97c 4. ./build_docker/./src/Interpreters/Context.cpp:4638: DB::Context::checkCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x00000000337930cf 5. ./build_docker/./src/Interpreters/Context.cpp:4676: DB::Context::checkTableCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x0000000033793449 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000003a2d0651 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:294: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492c118 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:43.493561 [ 25833 ] {200fc813-226d-4a54-ab34-5c0e6d2570cf} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1\n': (at row 2) . (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b265983 5. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b3a4185 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b39f4e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3a6fbc 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:12:44.170559 [ 16278 ] {200fc813-226d-4a54-ab34-5c0e6d2570cf} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1,2,3]\n': (at row 1) : (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_0j9fqufj_data1.jsonl): While executing JSONEachRowRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41526) (comment: 02267_file_globs_schema_inference.sh) (in query: select * from file('02267_file_globs_schema_inference_test_0j9fqufj_data*.jsonl') settings schema_inference_use_cache_for_file=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b265983 5. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:44.174732 [ 16278 ] {200fc813-226d-4a54-ab34-5c0e6d2570cf} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1,2,3]\n': (at row 1) : (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_0j9fqufj_data1.jsonl): While executing JSONEachRowRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b265983 5. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2660e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:44.200172 [ 610 ] {333aff4f-721b-41b9-9d79-4954a5f75ddf} executeQuery: Code: 359. DB::Exception: Table or Partition in test_z3rytu0n.test_max_size_drop was not dropped. Reason: 1. Size (4.13 KB) is greater than max_[table/partition]_size_to_drop (1.00 B) 2. File '/var/lib/clickhouse/flags/force_drop_table' intended to force DROP doesn't exist How to fix this: 1. Either increase (or set to zero) max_[table/partition]_size_to_drop in server config 2. Either pass a bigger (or set to zero) max_[table/partition]_size_to_drop through query settings 3. Either create forcing file /var/lib/clickhouse/flags/force_drop_table and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/force_drop_table' && sudo chmod 666 '/var/lib/clickhouse/flags/force_drop_table'. (TABLE_SIZE_EXCEEDS_MAX_DROP_SIZE_LIMIT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41524) (comment: 02932_query_settings_max_size_drop.sql) (in query: ALTER TABLE test_max_size_drop DROP PARTITION tuple() SETTINGS max_partition_size_to_drop = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&, String&&, char const*&&, String&&, String&&, String&&) @ 0x00000000337be97c 4. ./build_docker/./src/Interpreters/Context.cpp:4638: DB::Context::checkCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x00000000337930cf 5. ./build_docker/./src/Interpreters/Context.cpp:4699: DB::Context::checkPartitionCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x0000000033793629 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkPartitionCanBeDropped(std::shared_ptr const&, std::shared_ptr) @ 0x00000000397be68e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d06d9 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:44.201633 [ 610 ] {333aff4f-721b-41b9-9d79-4954a5f75ddf} TCPHandler: Code: 359. DB::Exception: Table or Partition in test_z3rytu0n.test_max_size_drop was not dropped. Reason: 1. Size (4.13 KB) is greater than max_[table/partition]_size_to_drop (1.00 B) 2. File '/var/lib/clickhouse/flags/force_drop_table' intended to force DROP doesn't exist How to fix this: 1. Either increase (or set to zero) max_[table/partition]_size_to_drop in server config 2. Either pass a bigger (or set to zero) max_[table/partition]_size_to_drop through query settings 3. Either create forcing file /var/lib/clickhouse/flags/force_drop_table and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/force_drop_table' && sudo chmod 666 '/var/lib/clickhouse/flags/force_drop_table'. (TABLE_SIZE_EXCEEDS_MAX_DROP_SIZE_LIMIT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&, String&&, char const*&&, String&&, String&&, String&&) @ 0x00000000337be97c 4. ./build_docker/./src/Interpreters/Context.cpp:4638: DB::Context::checkCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x00000000337930cf 5. ./build_docker/./src/Interpreters/Context.cpp:4699: DB::Context::checkPartitionCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x0000000033793629 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkPartitionCanBeDropped(std::shared_ptr const&, std::shared_ptr) @ 0x00000000397be68e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d06d9 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:44.980182 [ 610 ] {7fdb4515-4bc9-41b9-9d5c-162f2b2b280c} executeQuery: Code: 359. DB::Exception: Table or Partition in test_z3rytu0n.test_max_size_drop was not dropped. Reason: 1. Size (4.13 KB) is greater than max_[table/partition]_size_to_drop (1.00 B) 2. File '/var/lib/clickhouse/flags/force_drop_table' intended to force DROP doesn't exist How to fix this: 1. Either increase (or set to zero) max_[table/partition]_size_to_drop in server config 2. Either pass a bigger (or set to zero) max_[table/partition]_size_to_drop through query settings 3. Either create forcing file /var/lib/clickhouse/flags/force_drop_table and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/force_drop_table' && sudo chmod 666 '/var/lib/clickhouse/flags/force_drop_table'. (TABLE_SIZE_EXCEEDS_MAX_DROP_SIZE_LIMIT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41524) (comment: 02932_query_settings_max_size_drop.sql) (in query: ALTER TABLE test_max_size_drop DROP PART 'all_1_1_0' SETTINGS max_partition_size_to_drop = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&, String&&, char const*&&, String&&, String&&, String&&) @ 0x00000000337be97c 4. ./build_docker/./src/Interpreters/Context.cpp:4638: DB::Context::checkCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x00000000337930cf 5. ./build_docker/./src/Interpreters/Context.cpp:4699: DB::Context::checkPartitionCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x0000000033793629 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397bfaf1 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:44.981579 [ 610 ] {7fdb4515-4bc9-41b9-9d5c-162f2b2b280c} TCPHandler: Code: 359. DB::Exception: Table or Partition in test_z3rytu0n.test_max_size_drop was not dropped. Reason: 1. Size (4.13 KB) is greater than max_[table/partition]_size_to_drop (1.00 B) 2. File '/var/lib/clickhouse/flags/force_drop_table' intended to force DROP doesn't exist How to fix this: 1. Either increase (or set to zero) max_[table/partition]_size_to_drop in server config 2. Either pass a bigger (or set to zero) max_[table/partition]_size_to_drop through query settings 3. Either create forcing file /var/lib/clickhouse/flags/force_drop_table and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/force_drop_table' && sudo chmod 666 '/var/lib/clickhouse/flags/force_drop_table'. (TABLE_SIZE_EXCEEDS_MAX_DROP_SIZE_LIMIT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&, String&&, char const*&&, String&&, String&&, String&&) @ 0x00000000337be97c 4. ./build_docker/./src/Interpreters/Context.cpp:4638: DB::Context::checkCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x00000000337930cf 5. ./build_docker/./src/Interpreters/Context.cpp:4699: DB::Context::checkPartitionCanBeDropped(String const&, String const&, unsigned long const&, unsigned long const&) const @ 0x0000000033793629 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397bfaf1 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:46.311671 [ 16260 ] {f73436ac-345c-46ae-9ae1-4052ffeb1b29} executeQuery: Code: 47. DB::Exception: Unknown identifier 'xyz' inside COLUMNS matcher. In scope Scope node SELECT COLUMNS(bar, foo, xyz) APPLY length FROM test Identifier lookup to resolve state 2 Identifier foo EXPRESSION resolve result test_q0q0yr6j.test.foo place JOIN_TREE resolved from parent scopes 0 Identifier bar EXPRESSION resolve result test_q0q0yr6j.test.bar place JOIN_TREE resolved from parent scopes 0 Expression argument name to node 0 Alias name to expression node table size 0 Alias name to function node table size 0 Alias name to table expression node table size 0 CTE name to query node table size 0 WINDOW name to window node table size 0 Nodes with duplicated aliases size 0 Expression resolve process stack 1 Expression COLUMNS(bar, foo, xyz) APPLY length Table expressions in resolve process size 0 Non cached identifier lookups during expression resolve 0 Table expression node to data 1 Table expression node test_q0q0yr6j.test data Table expression name test_q0q0yr6j.test table expression description table database name test_q0q0yr6j table name test should qualify columns 1 columns size 12 Column name _block_offset column node COLUMN id: 0, column_name: _block_offset, result_type: UInt64, source_id: 1 Column name _block_number column node COLUMN id: 0, column_name: _block_number, result_type: UInt64, source_id: 1 Column name _part_offset column node COLUMN id: 0, column_name: _part_offset, result_type: UInt64, source_id: 1 Column name _row_exists column node COLUMN id: 0, column_name: _row_exists, result_type: UInt8, source_id: 1 Column name _partition_id column node COLUMN id: 0, column_name: _partition_id, result_type: LowCardinality(String), source_id: 1 Column name _part_uuid column node COLUMN id: 0, column_name: _part_uuid, result_type: UUID, source_id: 1 Column name _part_index column node COLUMN id: 0, column_name: _part_index, result_type: UInt64, source_id: 1 Column name _part_data_version column node COLUMN id: 0, column_name: _part_data_version, result_type: UInt64, source_id: 1 Column name _sample_factor column node COLUMN id: 0, column_name: _sample_factor, result_type: Float64, source_id: 1 Column name bar column node COLUMN id: 0, column_name: bar, result_type: String, source_id: 1 Column name _part column node COLUMN id: 0, column_name: _part, result_type: LowCardinality(String), source_id: 1 Column name foo column node COLUMN id: 0, column_name: foo, result_type: String, source_id: 1 Use identifier lookup to result cache 1 Subquery depth 0 . (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41566) (comment: 03152_analyzer_columns_list.sql) (in query: SELECT COLUMNS(bar, foo, xyz) APPLY (length) FROM test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1878: DB::QueryAnalyzer::resolveUnqualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334bbdf5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be204 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:46.313292 [ 16260 ] {f73436ac-345c-46ae-9ae1-4052ffeb1b29} TCPHandler: Code: 47. DB::Exception: Unknown identifier 'xyz' inside COLUMNS matcher. In scope Scope node SELECT COLUMNS(bar, foo, xyz) APPLY length FROM test Identifier lookup to resolve state 2 Identifier foo EXPRESSION resolve result test_q0q0yr6j.test.foo place JOIN_TREE resolved from parent scopes 0 Identifier bar EXPRESSION resolve result test_q0q0yr6j.test.bar place JOIN_TREE resolved from parent scopes 0 Expression argument name to node 0 Alias name to expression node table size 0 Alias name to function node table size 0 Alias name to table expression node table size 0 CTE name to query node table size 0 WINDOW name to window node table size 0 Nodes with duplicated aliases size 0 Expression resolve process stack 1 Expression COLUMNS(bar, foo, xyz) APPLY length Table expressions in resolve process size 0 Non cached identifier lookups during expression resolve 0 Table expression node to data 1 Table expression node test_q0q0yr6j.test data Table expression name test_q0q0yr6j.test table expression description table database name test_q0q0yr6j table name test should qualify columns 1 columns size 12 Column name _block_offset column node COLUMN id: 0, column_name: _block_offset, result_type: UInt64, source_id: 1 Column name _block_number column node COLUMN id: 0, column_name: _block_number, result_type: UInt64, source_id: 1 Column name _part_offset column node COLUMN id: 0, column_name: _part_offset, result_type: UInt64, source_id: 1 Column name _row_exists column node COLUMN id: 0, column_name: _row_exists, result_type: UInt8, source_id: 1 Column name _partition_id column node COLUMN id: 0, column_name: _partition_id, result_type: LowCardinality(String), source_id: 1 Column name _part_uuid column node COLUMN id: 0, column_name: _part_uuid, result_type: UUID, source_id: 1 Column name _part_index column node COLUMN id: 0, column_name: _part_index, result_type: UInt64, source_id: 1 Column name _part_data_version column node COLUMN id: 0, column_name: _part_data_version, result_type: UInt64, source_id: 1 Column name _sample_factor column node COLUMN id: 0, column_name: _sample_factor, result_type: Float64, source_id: 1 Column name bar column node COLUMN id: 0, column_name: bar, result_type: String, source_id: 1 Column name _part column node COLUMN id: 0, column_name: _part, result_type: LowCardinality(String), source_id: 1 Column name foo column node COLUMN id: 0, column_name: foo, result_type: String, source_id: 1 Use identifier lookup to result cache 1 Subquery depth 0 . (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1878: DB::QueryAnalyzer::resolveUnqualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334bbdf5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be204 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:47.427408 [ 1279 ] {} test_dr3lxau3.replicated_table_detach_all2 (45bb5a79-c36d-41ce-b2dd-4d4bad0df064): Part 1_2_2_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.06.18 11:12:47.966881 [ 1588 ] {2dd5713b-8b71-4c2a-8cf4-c770a84ccd5f} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE replicated_table_detach_all1 FETCH PARTITION ALL FROM '/clickhouse/tables/test_00753_{database}/replicated_table_detach_all1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:47.968407 [ 1588 ] {2dd5713b-8b71-4c2a-8cf4-c770a84ccd5f} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.336781 [ 1588 ] {1533f1cf-3b42-4a66-87e7-06ee1d1992e1} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: -- test PARTITION ALL ALTER TABLE partition_all2 REPLACE PARTITION ALL FROM partition_all;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.338016 [ 1588 ] {1533f1cf-3b42-4a66-87e7-06ee1d1992e1} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.347994 [ 1588 ] {87017a35-7ca5-4d99-949e-6932e0e0b986} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all MOVE PARTITION ALL TO TABLE partition_all2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.348762 [ 1588 ] {87017a35-7ca5-4d99-949e-6932e0e0b986} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.833847 [ 1588 ] {59d05ebc-95b1-4e79-aa61-76d3f57a8f62} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 CLEAR INDEX p IN PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974ee47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.835451 [ 1588 ] {59d05ebc-95b1-4e79-aa61-76d3f57a8f62} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974ee47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.862234 [ 1588 ] {ea1f17d5-1394-4d35-8925-2c2135744256} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 CLEAR COLUMN q IN PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974ee47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:48.863658 [ 1588 ] {ea1f17d5-1394-4d35-8925-2c2135744256} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974ee47 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:49.349468 [ 1588 ] {68072028-b926-4fa4-8b1b-7d451dd36e37} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 UPDATE q = q + 1 IN PARTITION ALL where p = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034f67c2e 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::prepare(bool) @ 0x0000000034f7a777 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f6fca9 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f6cf4c 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034858070 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:49.351132 [ 1588 ] {68072028-b926-4fa4-8b1b-7d451dd36e37} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034f67c2e 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::prepare(bool) @ 0x0000000034f7a777 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f6fca9 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f6cf4c 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034858070 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:49.363112 [ 1588 ] {22906695-a966-46b0-8d1b-9941e7c6a1da} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 FREEZE PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:49.364277 [ 1588 ] {22906695-a966-46b0-8d1b-9941e7c6a1da} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd3c9 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:49.824402 [ 1588 ] {c0b03ecf-a0f6-4bdb-8e0a-0aecd53ddd03} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: CHECK TABLE partition_all2 PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003a35092a 6. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:0: DB::InterpreterCheckQuery::execute() @ 0x00000000359f8ffd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:49.825822 [ 1588 ] {c0b03ecf-a0f6-4bdb-8e0a-0aecd53ddd03} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003a35092a 6. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:0: DB::InterpreterCheckQuery::execute() @ 0x00000000359f8ffd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:50.266688 [ 1588 ] {ac9f1ee2-9dfe-4f84-bbf5-bd8bc8e7f67e} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41574) (comment: 00753_alter_attach.sql) (in query: OPTIMIZE TABLE partition_all2 PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d5ef 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:50.268065 [ 1588 ] {ac9f1ee2-9dfe-4f84-bbf5-bd8bc8e7f67e} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000397665f5 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d5ef 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:50.285196 [ 610 ] {918520ed-b261-4b13-ad10-14988b94663f} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_n3s5t6zh.simple (2ef84126-99e8-4553-907e-697cedb24ef0). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41760) (comment: 01666_merge_tree_max_query_limit.sh) (in query: select * from simple), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000974070d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8265: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003986b1f8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8291: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003986c35f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000039a4967a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2061: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1acc0 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:50.288049 [ 610 ] {918520ed-b261-4b13-ad10-14988b94663f} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_n3s5t6zh.simple (2ef84126-99e8-4553-907e-697cedb24ef0). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000974070d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8265: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003986b1f8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8291: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003986c35f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000039a4967a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2061: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1acc0 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:52.424750 [ 16279 ] {8821d2b3-fe86-4889-8b48-855cd78c4262} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_n3s5t6zh.simple (2ef84126-99e8-4553-907e-697cedb24ef0). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36066) (comment: 01666_merge_tree_max_query_limit.sh) (in query: select * from simple where i = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000974070d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8265: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003986b1f8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8291: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003986c35f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000039a4967a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2061: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1acc0 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:52.427025 [ 16279 ] {8821d2b3-fe86-4889-8b48-855cd78c4262} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_n3s5t6zh.simple (2ef84126-99e8-4553-907e-697cedb24ef0). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000974070d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8265: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003986b1f8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8291: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003986c35f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000039a4967a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2061: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1acc0 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:55.189454 [ 16279 ] {7f7ceb2b-5717-4d60-85ad-1190266a89fd} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_n3s5t6zh.simple (2ef84126-99e8-4553-907e-697cedb24ef0). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36236) (comment: 01666_merge_tree_max_query_limit.sh) (in query: select * from simple where i = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000974070d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8265: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003986b1f8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8291: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003986c35f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000039a4967a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2061: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1acc0 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:55.191744 [ 16279 ] {7f7ceb2b-5717-4d60-85ad-1190266a89fd} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_n3s5t6zh.simple (2ef84126-99e8-4553-907e-697cedb24ef0). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000974070d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8265: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003986b1f8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8291: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003986c35f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000039a4967a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2061: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1acc0 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:56.059853 [ 1814 ] {long_running_query-test_n3s5t6zh} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41730) (comment: 01666_merge_tree_max_query_limit.sh) (in query: select sleepEachRow(0.1) from simple settings max_block_size = 1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:56.064188 [ 1814 ] {long_running_query-test_n3s5t6zh} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:59.256787 [ 610 ] {0f83106e-da8e-4f7f-a838-dd902c453ce9} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36296) (comment: 01785_parallel_formatting_memory.sh) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. ./src/Common/PODArray.h:0: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036ffd008 9. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036fc9d75 10. ./build_docker/./src/Columns/ColumnConst.cpp:0: DB::ColumnConst::convertToFullColumn() const @ 0x00000000370d3384 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000370d7b2e 12. ./build_docker/./src/Formats/NativeWriter.cpp:0: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7bcae 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 14. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:12:59.261086 [ 610 ] {0f83106e-da8e-4f7f-a838-dd902c453ce9} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. ./src/Common/PODArray.h:0: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036ffd008 9. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036fc9d75 10. ./build_docker/./src/Columns/ColumnConst.cpp:0: DB::ColumnConst::convertToFullColumn() const @ 0x00000000370d3384 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000370d7b2e 12. ./build_docker/./src/Formats/NativeWriter.cpp:0: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7bcae 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 14. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:00.012325 [ 25622 ] {} test_eme708vt.replace_partition_dest2_2 (301a6242-2786-4dd1-8e0d-0c5e758a3220): Table /test/02271_replace_partition_many/test_eme708vt/dest2/replicas/2 is already started to be removing by another replica right now 2025.06.18 11:13:00.141900 [ 1534 ] {ea7cc615-918c-416b-b7d2-5e11f039d4ed} executeQuery: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1000000000' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0cff2 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032506531 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:00.143653 [ 1534 ] {ea7cc615-918c-416b-b7d2-5e11f039d4ed} TCPHandler: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0cff2 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032506531 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:00.164283 [ 1534 ] {cb51bca8-7817-4a1b-b555-213145d0daab} executeQuery: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '-1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1000000000' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0cff2 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032506531 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:00.165686 [ 1534 ] {cb51bca8-7817-4a1b-b555-213145d0daab} TCPHandler: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '-1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0cff2 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032506531 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:00.733108 [ 1588 ] {143fe799-3faa-4ee5-a62c-7f09e9a0bf06} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36364) (comment: 01785_parallel_formatting_memory.sh) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. ./src/Common/PODArray.h:0: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036ffd008 9. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036fc9d75 10. ./build_docker/./src/Columns/ColumnConst.cpp:0: DB::ColumnConst::convertToFullColumn() const @ 0x00000000370d3384 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000370d7b2e 12. ./build_docker/./src/Formats/NativeWriter.cpp:0: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7bcae 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 14. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:00.735988 [ 1588 ] {143fe799-3faa-4ee5-a62c-7f09e9a0bf06} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. ./src/Common/PODArray.h:0: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036ffd008 9. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036fc9d75 10. ./build_docker/./src/Columns/ColumnConst.cpp:0: DB::ColumnConst::convertToFullColumn() const @ 0x00000000370d3384 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000370d7b2e 12. ./build_docker/./src/Formats/NativeWriter.cpp:0: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7bcae 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 14. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:00.935944 [ 1534 ] {149ed3b9-cffe-43b2-95f3-b76906472ef2} executeQuery: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1000000000000000000' AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0e54a 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032507731 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:00.937554 [ 1534 ] {149ed3b9-cffe-43b2-95f3-b76906472ef2} TCPHandler: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0e54a 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032507731 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:00.960333 [ 1534 ] {712338ea-4c74-4f24-8788-572a283ad9ed} executeQuery: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '-1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1000000000000000000' AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0e54a 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032507731 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:00.961756 [ 1534 ] {712338ea-4c74-4f24-8788-572a283ad9ed} TCPHandler: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '-1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x0000000031a0e54a 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000032507731 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:01.769270 [ 1534 ] {53a2fc65-7f1e-4437-a2d8-83fadcf66db3} executeQuery: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '100000000000000000000000000000000000000' AS x, toDecimal128(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a0fbe4 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000003250894f 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 8. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 9. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:01.770648 [ 1534 ] {53a2fc65-7f1e-4437-a2d8-83fadcf66db3} TCPHandler: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a0fbe4 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000003250894f 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 8. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 9. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:01.789407 [ 1534 ] {331bf512-b210-40d7-8ac6-52785e43df72} executeQuery: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '-100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-100000000000000000000000000000000000000' AS x, toDecimal128(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a0fbe4 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000003250894f 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 8. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 9. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:01.790885 [ 1534 ] {331bf512-b210-40d7-8ac6-52785e43df72} TCPHandler: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '-100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./src/IO/readDecimalText.h:96: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x0000000031a0fbe4 5. ./src/IO/readDecimalText.h:0: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000003250894f 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 8. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 9. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:13:02.588200 [ 1534 ] {f64a564f-0cc0-4fed-86c6-73c178654d7b} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1' AS x, toDecimal32(x, 9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:02.589976 [ 1534 ] {f64a564f-0cc0-4fed-86c6-73c178654d7b} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:02.608359 [ 1534 ] {5685d797-457c-4c90-a11c-47041390fdd9} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '-1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1' AS x, toDecimal32(x, 9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:02.609349 [ 1534 ] {5685d797-457c-4c90-a11c-47041390fdd9} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '-1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:03.402839 [ 1534 ] {425613be-cfcf-43e2-b7f6-00439af0d54c} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1' AS x, toDecimal64(x, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:03.404439 [ 1534 ] {425613be-cfcf-43e2-b7f6-00439af0d54c} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:03.424348 [ 1534 ] {c92726c8-7b08-4c0e-be4b-475330e88b25} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '-1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1' AS x, toDecimal64(x, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:03.425629 [ 1534 ] {c92726c8-7b08-4c0e-be4b-475330e88b25} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '-1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.216984 [ 1534 ] {7143ea2a-0da4-4894-be83-31b149464383} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1' AS x, toDecimal128(x, 38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.218622 [ 1534 ] {7143ea2a-0da4-4894-be83-31b149464383} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.237848 [ 1534 ] {b326cdd2-4e46-418c-a008-59c3d4b93e64} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '-1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1' AS x, toDecimal128(x, 38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.239104 [ 1534 ] {b326cdd2-4e46-418c-a008-59c3d4b93e64} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '-1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.541956 [ 1587 ] {1aaccf72-e5dc-412c-8ea5-6336744be962} executeQuery: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40794) (comment: 02922_respect_nulls_Nullable.sql) (in query: -- { echoOn } Select anyOrNull(tp) FROM (Select (number, number) as tp from numbers(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda2149 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda1ac4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fda180c 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:13:04.543499 [ 1587 ] {1aaccf72-e5dc-412c-8ea5-6336744be962} TCPHandler: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda2149 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda1ac4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fda180c 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:13:04.566580 [ 1587 ] {ce70b1b0-1e8b-4b37-85ad-363e6a6b339b} executeQuery: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40794) (comment: 02922_respect_nulls_Nullable.sql) (in query: Select anyOrNull(tp) FROM (Select (number, number) as tp from numbers(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda2149 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda1ac4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fda180c 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:13:04.567945 [ 1587 ] {ce70b1b0-1e8b-4b37-85ad-363e6a6b339b} TCPHandler: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda2149 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fda1ac4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fda180c 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:13:04.597711 [ 1534 ] {93d0f1cb-185c-4f14-b5e8-f5ad2d7bd45e} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '1e9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1e9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.599269 [ 1534 ] {93d0f1cb-185c-4f14-b5e8-f5ad2d7bd45e} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '1e9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.617237 [ 1534 ] {1ec46be0-0f53-4fc1-b280-7efb52b74019} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.626958 [ 1534 ] {1ec46be0-0f53-4fc1-b280-7efb52b74019} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.645694 [ 1534 ] {45a7be8a-2ffd-4ba6-a7d2-d8e7113628e9} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e18. Expected to read decimal with scale 0 and precision 18: In scope SELECT '1E18' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1E18' AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.646951 [ 1534 ] {45a7be8a-2ffd-4ba6-a7d2-d8e7113628e9} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e18. Expected to read decimal with scale 0 and precision 18: In scope SELECT '1E18' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.669435 [ 1534 ] {501a9433-8cbe-4705-ba31-6b66d11830fc} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e18. Expected to read decimal with scale 0 and precision 18: In scope SELECT '-1e18' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1e18' AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.670999 [ 1534 ] {501a9433-8cbe-4705-ba31-6b66d11830fc} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e18. Expected to read decimal with scale 0 and precision 18: In scope SELECT '-1e18' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.692179 [ 1534 ] {96dffcf4-8e3c-4c89-9401-51d3a3b77842} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e38. Expected to read decimal with scale 0 and precision 38: In scope SELECT '1e38' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1e38' AS x, toDecimal128(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.693810 [ 1534 ] {96dffcf4-8e3c-4c89-9401-51d3a3b77842} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e38. Expected to read decimal with scale 0 and precision 38: In scope SELECT '1e38' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.714733 [ 1534 ] {f540b907-869a-4484-ab66-ebbbffe1e480} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e38. Expected to read decimal with scale 0 and precision 38: In scope SELECT '-1E38' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1E38' AS x, toDecimal128(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.716122 [ 1534 ] {f540b907-869a-4484-ab66-ebbbffe1e480} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e38. Expected to read decimal with scale 0 and precision 38: In scope SELECT '-1E38' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.734804 [ 1534 ] {79a21dc4-9a84-43ec-88f7-a9db83856819} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '1e0' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1e0' AS x, toDecimal32(x, 9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.736201 [ 1534 ] {79a21dc4-9a84-43ec-88f7-a9db83856819} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '1e0' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.758230 [ 1534 ] {1b012c65-40f5-476e-917d-2f48b9cd5544} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '-1e-0' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1e-0' AS x, toDecimal32(x, 9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.759771 [ 1534 ] {1b012c65-40f5-476e-917d-2f48b9cd5544} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '-1e-0' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009212839 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092002c1 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.782727 [ 1534 ] {10a790b8-3a4e-4ee3-8bb0-de93cdfb932b} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '1e0' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1e0' AS x, toDecimal64(x, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.784451 [ 1534 ] {10a790b8-3a4e-4ee3-8bb0-de93cdfb932b} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '1e0' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.806898 [ 1534 ] {de1bf557-189e-4832-89d2-5acd947868db} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '-1e-0' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1e-0' AS x, toDecimal64(x, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.808768 [ 1534 ] {de1bf557-189e-4832-89d2-5acd947868db} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '-1e-0' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000009266b8e 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000925441d 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921b2ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.832988 [ 1534 ] {0db6550a-7749-44e9-bd23-6f84a8a5c833} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '1e-0' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '1e-0' AS x, toDecimal128(x, 38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.834734 [ 1534 ] {0db6550a-7749-44e9-bd23-6f84a8a5c833} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: 1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '1e-0' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.858983 [ 1534 ] {e563d2b7-7cbd-4cd8-b535-dc993bd57cb0} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '-1e0' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT '-1e0' AS x, toDecimal128(x, 38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:04.860713 [ 1534 ] {e563d2b7-7cbd-4cd8-b535-dc993bd57cb0} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '-1e0' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000092bc539 7. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092aa51a 8. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926f6ff 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:05.499203 [ 1587 ] {8cf2e448-e47c-40ce-b01c-0bcdea0121b4} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nullsOrNull, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nullsOrNull instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40794) (comment: 02922_respect_nulls_Nullable.sql) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select first_value_respect_nullsOrNullState(number) as t FROM numbers(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:61: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fd62c0e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:05.501016 [ 1587 ] {8cf2e448-e47c-40ce-b01c-0bcdea0121b4} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nullsOrNull, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nullsOrNull instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:61: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fd62c0e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:05.526393 [ 1587 ] {2f99c248-3d38-44d6-b0af-1cbf3221845c} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of any_respect_nullsOrNull. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40794) (comment: 02922_respect_nulls_Nullable.sql) (in query: SELECT first_value_respect_nullsOrNullMerge(t) FROM (Select first_value_respect_nullsState(number) as t FROM numbers(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:61: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fd62c0e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:05.527897 [ 1587 ] {2f99c248-3d38-44d6-b0af-1cbf3221845c} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of any_respect_nullsOrNull. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:61: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fd62c0e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:06.158923 [ 16278 ] {d9785b86-6b57-483d-945c-70bbac718cce} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64('3000-01-01 12:00:00.12345', 0) + toIntervalNanosecond(0). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40812) (comment: 00514_interval_operators.sql) (in query: select toDateTime64('3000-01-01 12:00:00.12345', 0) + interval 0 nanosecond;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008674592 5. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b84d500 6. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b848478 7. DB::DateTimeAddIntervalImpl::execute(DB::AddNanosecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b82f2ca 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b82a5e0 9. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001a094f0b 17. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a091fc9 18. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a08e47c 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 20. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 22. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 23. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 25. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 28. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 2025.06.18 11:13:06.160240 [ 16278 ] {d9785b86-6b57-483d-945c-70bbac718cce} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64('3000-01-01 12:00:00.12345', 0) + toIntervalNanosecond(0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008674592 5. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b84d500 6. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b848478 7. DB::DateTimeAddIntervalImpl::execute(DB::AddNanosecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b82f2ca 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b82a5e0 9. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001a094f0b 17. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a091fc9 18. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a08e47c 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 20. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 22. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 23. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 25. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 28. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 2025.06.18 11:13:06.995082 [ 16278 ] {d86c2cbe-929d-4e36-9a64-8d324e54d157} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT materialize(toDate('2000-01-01')) + toIntervalNanosecond(1) FROM numbers(0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40812) (comment: 00514_interval_operators.sql) (in query: -- Check that the error is thrown during typechecking, not execution. select materialize(toDate('2000-01-01')) + interval 1 nanosecond from numbers(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b86aca5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b82b187 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:06.996521 [ 16278 ] {d86c2cbe-929d-4e36-9a64-8d324e54d157} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT materialize(toDate('2000-01-01')) + toIntervalNanosecond(1) FROM numbers(0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b86aca5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b82b187 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:07.781709 [ 1588 ] {965430dc-3d5e-4c19-9cd0-c554f882f1f4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: UInt8: In scope SELECT JSONArrayLength(2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40874) (comment: 02568_json_array_length.sql) (in query: select JSONArrayLength(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionJSONArrayLength::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b612831 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:13:07.783165 [ 1588 ] {965430dc-3d5e-4c19-9cd0-c554f882f1f4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: UInt8: In scope SELECT JSONArrayLength(2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionJSONArrayLength::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b612831 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:13:07.798639 [ 1588 ] {bc0d516c-93d9-4eb9-922b-367b85291e74} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40874) (comment: 02568_json_array_length.sql) (in query: select JSONArrayLength();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:07.799834 [ 1588 ] {bc0d516c-93d9-4eb9-922b-367b85291e74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:08.996214 [ 1534 ] {adb5fa34-322a-4fcf-814d-491731c0df4e} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 9 digits were read: 123456789e0. Expected to read decimal with scale 1 and precision 9: In scope SELECT CAST('123456789', 'Decimal(9,1)'). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT CAST('123456789', 'Decimal(9,1)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000008c8233c 7. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIiEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c45eed 8. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIiEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c3befd 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:08.997642 [ 1534 ] {adb5fa34-322a-4fcf-814d-491731c0df4e} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 9 digits were read: 123456789e0. Expected to read decimal with scale 1 and precision 9: In scope SELECT CAST('123456789', 'Decimal(9,1)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250b807 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000003250678b 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268ca3e 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000008c8233c 7. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIiEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c45eed 8. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIiEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c3befd 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:09.785366 [ 1534 ] {0d2ee77f-6b02-433c-b42d-fc8b32c28e47} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 18 digits were read: 123456789123456789e0. Expected to read decimal with scale 1 and precision 18: In scope SELECT CAST('123456789123456789', 'Decimal(18,1)'). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT CAST('123456789123456789', 'Decimal(18,1)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000008cc8a91 7. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIlEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c8d4ba 8. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIlEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c834bd 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:09.787079 [ 1534 ] {0d2ee77f-6b02-433c-b42d-fc8b32c28e47} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 18 digits were read: 123456789123456789e0. Expected to read decimal with scale 1 and precision 18: In scope SELECT CAST('123456789123456789', 'Decimal(18,1)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000003250d747 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000325079c0 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000003268f4be 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000008cc8a91 7. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIlEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c8d4ba 8. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIlEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c834bd 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:10.577005 [ 1534 ] {2b417c96-1e50-4a7f-b8a9-7aef70db7f00} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 38 digits were read: 12345678901234567890123456789012345678e0. Expected to read decimal with scale 1 and precision 38: In scope SELECT CAST('12345678901234567890123456789012345678', 'Decimal(38,1)'). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36324) (comment: 00700_decimal_casts.sql) (in query: SELECT CAST('12345678901234567890123456789012345678', 'Decimal(38,1)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000008d0fc17 7. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS7_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISF_EERNSC_6vectorINS_21ColumnWithTypeAndNameENSC_9allocatorISK_EEEERKNSC_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESU_PKSB_bENKUlSO_SU_SX_mE_clESO_SU_SX_mEUlRS10_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008cd3ff9 8. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIN4wide7integerILm128EiEEEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKS11_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008cc9c9d 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:10.578405 [ 1534 ] {2b417c96-1e50-4a7f-b8a9-7aef70db7f00} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 38 digits were read: 12345678901234567890123456789012345678e0. Expected to read decimal with scale 1 and precision 38: In scope SELECT CAST('12345678901234567890123456789012345678', 'Decimal(38,1)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, wide::integer<128ul, int>&, int&, unsigned int&, unsigned int&) @ 0x000000003250f2c7 4. ./src/IO/readDecimalText.h:170: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000032508e86 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000032692220 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000008d0fc17 7. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS7_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISF_EERNSC_6vectorINS_21ColumnWithTypeAndNameENSC_9allocatorISK_EEEERKNSC_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESU_PKSB_bENKUlSO_SU_SX_mE_clESO_SU_SX_mEUlRS10_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008cd3ff9 8. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIN4wide7integerILm128EiEEEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKS11_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008cc9c9d 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:13:12.075223 [ 1587 ] {aaa5ed45-a9a8-402b-9f43-ae8992328efe} executeQuery: Code: 264. DB::Exception: Table 'test_wakq3xm6.testJoinTable (f7d50d45-b7a7-4eb8-9a0a-7faf16e936dc)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41012) (comment: 01050_engine_join_crash.sql) (in query: SELECT * FROM (SELECT * FROM numbers(10)) js1 INNER JOIN testJoinTable USING number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd525 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:12.076916 [ 1587 ] {aaa5ed45-a9a8-402b-9f43-ae8992328efe} TCPHandler: Code: 264. DB::Exception: Table 'test_wakq3xm6.testJoinTable (f7d50d45-b7a7-4eb8-9a0a-7faf16e936dc)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd525 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:15.765888 [ 610 ] {7a5408d7-93fe-4816-a8e6-27e6efadc6be} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.key = t2.key AND t2.key > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:15.767591 [ 610 ] {7a5408d7-93fe-4816-a8e6-27e6efadc6be} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:15.800157 [ 610 ] {fe9b6903-b71f-49e6-b477-8569a7051974} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.key = t2.key AND t1.key > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:15.801568 [ 610 ] {fe9b6903-b71f-49e6-b477-8569a7051974} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.239899 [ 610 ] {18ea6ceb-6cb6-4f0c-ac67-c265dc52727a} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.key = t2.key OR t1.val = t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd7fb3 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.241762 [ 610 ] {18ea6ceb-6cb6-4f0c-ac67-c265dc52727a} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd7fb3 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.770126 [ 610 ] {9c02a254-65b2-476b-a062-6cdbbca70e9a} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Anti. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 ANTI JOIN t2 ON t1.key = t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86a8aa 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b84881a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b849512 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8689f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aad8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032290034 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.771705 [ 610 ] {9c02a254-65b2-476b-a062-6cdbbca70e9a} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Anti. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86a8aa 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b84881a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b849512 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8689f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aad8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032290034 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.811449 [ 610 ] {f5237ccd-5842-496f-a08a-9100757ef4c9} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 SEMI JOIN t2 ON t1.key = t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86a8aa 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b84881a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b849512 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8689f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aad8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032290034 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.812978 [ 610 ] {f5237ccd-5842-496f-a08a-9100757ef4c9} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86a8aa 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b84881a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b849512 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8689f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aad8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032290034 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.854049 [ 610 ] {7c65b0b2-086a-4691-b4f9-e21fa4077b42} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 ANY JOIN t2 ON t1.key = t2.key SETTINGS any_join_distinct_right_table_keys = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86a8aa 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b84881a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b849512 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8689f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aad8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032290034 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.855887 [ 610 ] {7c65b0b2-086a-4691-b4f9-e21fa4077b42} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86a8aa 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b84881a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b849512 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8689f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aad8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032290034 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.882057 [ 610 ] {64d8fe7d-fd68-455e-afd3-408fc8e726d1} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 JOIN t2 USING (key) SETTINGS join_use_nulls = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:16.883725 [ 610 ] {64d8fe7d-fd68-455e-afd3-408fc8e726d1} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:17.390647 [ 610 ] {65b476ad-83ae-41ee-b567-2c39f56e8742} executeQuery: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM ( SELECT key, sum(val) AS val FROM t1 GROUP BY key WITH TOTALS ) as t1 JOIN ( SELECT key, sum(val) AS val FROM t2 GROUP BY key WITH TOTALS ) as t2 ON t1.key = t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000322906f2 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:17.392763 [ 610 ] {65b476ad-83ae-41ee-b567-2c39f56e8742} TCPHandler: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000322906f2 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:17.468600 [ 610 ] {342b23ad-2792-48f7-837c-4ac4ed72e816} executeQuery: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM t1 JOIN ( SELECT key, sum(val) AS val FROM t2 GROUP BY key WITH TOTALS ) as t2 ON t1.key = t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000322906f2 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:17.470420 [ 610 ] {342b23ad-2792-48f7-837c-4ac4ed72e816} TCPHandler: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000322906f2 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:17.534402 [ 610 ] {979671b2-305d-4c91-a54a-7a7aebd4e015} executeQuery: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02276_full_sort_join_unsupported.sql) (in query: SELECT * FROM ( SELECT key, sum(val) AS val FROM t1 GROUP BY key WITH TOTALS ) as t1 JOIN t2 ON t1.key = t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000322906f2 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:17.536088 [ 610 ] {979671b2-305d-4c91-a54a-7a7aebd4e015} TCPHandler: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000322906f2 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48c7e 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:19.219014 [ 16275 ] {60c241c4-bec2-416b-812d-622d1cb156b7} executeQuery: Code: 252. DB::Exception: Too many parts (10) in all partitions in total in table 'test_wb0uekoc.max_parts_in_total (592b322f-7adf-42c7-9bdb-269b199e00a6)'. This indicates wrong choice of partition key. The threshold can be modified with 'max_parts_in_total' setting in element in config.xml or with per-table setting. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52198) (comment: 00940_max_parts_in_total.sql) (in query: INSERT INTO max_parts_in_total SELECT 123;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f94626d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4545: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab242 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:19.221782 [ 16275 ] {60c241c4-bec2-416b-812d-622d1cb156b7} TCPHandler: Code: 252. DB::Exception: Too many parts (10) in all partitions in total in table 'test_wb0uekoc.max_parts_in_total (592b322f-7adf-42c7-9bdb-269b199e00a6)'. This indicates wrong choice of partition key. The threshold can be modified with 'max_parts_in_total' setting in element in config.xml or with per-table setting. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f94626d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4545: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab242 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:19.845222 [ 16275 ] {e7330c0b-bf7a-4f65-bb2c-1a1917b27c67} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52234) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f83d7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:19.846325 [ 16275 ] {e7330c0b-bf7a-4f65-bb2c-1a1917b27c67} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f83d7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:27.603713 [ 610 ] {b3995c2d-33ee-4f22-b6ef-d666f072052e} executeQuery: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'Expected argument of data type real'_String :: 2) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected argument of data type real'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49738) (comment: 02366_kql_func_math.sql) (in query: print isnan(4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001c578cfa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c572a7f 4. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:27.605391 [ 610 ] {b3995c2d-33ee-4f22-b6ef-d666f072052e} TCPHandler: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'Expected argument of data type real'_String :: 2) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected argument of data type real'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001c578cfa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c572a7f 4. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:28.021017 [ 1814 ] {ca2c52f1-5e63-424a-b9f8-c443a0cace68} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49806) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f83d7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:28.022134 [ 1814 ] {ca2c52f1-5e63-424a-b9f8-c443a0cace68} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f83d7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:28.645628 [ 610 ] {094421e2-fd66-4a68-8d58-39a5a1c629e6} executeQuery: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION if(_CAST(0_UInt8, 'UInt8'_String) :: 1, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 2, throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected argument of data type real'_String) :: 5) -> if(_CAST(0_UInt8, 'UInt8'_String), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected argument of data type real'_String)) Nullable(UInt8) : 4'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49738) (comment: 02366_kql_func_math.sql) (in query: print isnan(dynamic(null));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001c578cfa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c572a7f 4. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037434bf0 10. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x000000003804e322 11. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bf59f 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:28.647585 [ 610 ] {094421e2-fd66-4a68-8d58-39a5a1c629e6} TCPHandler: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION if(_CAST(0_UInt8, 'UInt8'_String) :: 1, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 2, throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected argument of data type real'_String) :: 5) -> if(_CAST(0_UInt8, 'UInt8'_String), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected argument of data type real'_String)) Nullable(UInt8) : 4'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001c578cfa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c572a7f 4. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037434bf0 10. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x000000003804e322 11. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bf59f 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:30.500353 [ 1583 ] {32698dae-f78d-4ffb-bc67-be8b8e2e905d} executeQuery: Code: 80. DB::Exception: Temporary tables cannot be created with Replicated, Shared or KeeperMap table engines. (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49886) (comment: 02525_different_engines_in_temporary_tables.sql) (in query: CREATE TEMPORARY TABLE table_replicated_merge_tree_02525 (`id` UInt64, `info` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_02525/table_replicated_merge_tree_02525', 'r1') PRIMARY KEY id ORDER BY id SETTINGS index_granularity = 45602, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 114, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 207698753, compact_parts_max_granules_to_buffer = 189, compact_parts_merge_max_bytes_to_prefetch_part = 14925826, merge_max_block_size = 8551, old_parts_lifetime = 396., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 98923474, index_granularity_bytes = 461705, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 52104, primary_key_compress_block_size = 86193), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:944: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000348ac258 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:752: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489f311 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:30.501826 [ 1583 ] {32698dae-f78d-4ffb-bc67-be8b8e2e905d} TCPHandler: Code: 80. DB::Exception: Temporary tables cannot be created with Replicated, Shared or KeeperMap table engines. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:944: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000348ac258 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:752: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489f311 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:30.527158 [ 1583 ] {4abb3e05-3ed7-44a3-9bef-9b965b806a37} executeQuery: Code: 80. DB::Exception: Temporary tables cannot be created with Replicated, Shared or KeeperMap table engines. (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49886) (comment: 02525_different_engines_in_temporary_tables.sql) (in query: CREATE TEMPORARY TABLE table_keeper_map_02525 ( key String, value UInt32 ) Engine=KeeperMap('/' || currentDatabase() || '/test02525') PRIMARY KEY(key);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:944: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000348ac258 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:752: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489f311 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:30.528442 [ 1583 ] {4abb3e05-3ed7-44a3-9bef-9b965b806a37} TCPHandler: Code: 80. DB::Exception: Temporary tables cannot be created with Replicated, Shared or KeeperMap table engines. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:944: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000348ac258 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:752: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489f311 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:31.121690 [ 16279 ] {6dba05c7-49b2-4b5d-a8dd-1d1be9b483d2} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'xyz' in scope SELECT xyz. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49936) (comment: 00380_client_break_at_exception_in_batch_mode.sh) (in query: SELECT xyz;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:31.124118 [ 16279 ] {6dba05c7-49b2-4b5d-a8dd-1d1be9b483d2} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'xyz' in scope SELECT xyz. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:31.663152 [ 1587 ] {644c3372-5738-40f5-9aaa-4ccde7f851f4} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49950) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:121: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000395f786d 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:594: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x000000003962146f 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x0000000039620a7c 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039620080 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039635140 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a361d 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f7c23 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:31.664279 [ 1587 ] {644c3372-5738-40f5-9aaa-4ccde7f851f4} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:121: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000395f786d 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:594: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x000000003962146f 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x0000000039620a7c 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039620080 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039635140 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a361d 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f7c23 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:37.879434 [ 610 ] {23256b45-4027-4ffb-8d25-582815b914a2} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46804) (comment: 00550_join_insert_select.sh) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY INNER JOIN test3_00550 USING (id) SETTINGS any_join_distinct_right_table_keys=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000003326762f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9d3a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:37.882918 [ 610 ] {23256b45-4027-4ffb-8d25-582815b914a2} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000003326762f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9d3a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:37.920043 [ 610 ] {b9f9138a-99d5-4b3a-bf72-c60c558baeee} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46804) (comment: 00550_join_insert_select.sh) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY LEFT OUTER JOIN test3_00550 USING (id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000003326762f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9d3a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:37.922602 [ 610 ] {b9f9138a-99d5-4b3a-bf72-c60c558baeee} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000003326762f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9d3a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:40.117127 [ 1534 ] {48c7f65b-5416-4688-8a1c-7c880f285d1f} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46930) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:121: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000395f786d 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:594: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x000000003962146f 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x0000000039620a7c 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039620080 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039635140 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a361d 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f7c23 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:40.118186 [ 1534 ] {48c7f65b-5416-4688-8a1c-7c880f285d1f} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:121: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000395f786d 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:594: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x000000003962146f 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x0000000039620a7c 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039620080 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039635140 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a361d 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f7c23 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:42.852868 [ 1814 ] {53b0b6e6-b5c4-40b7-af4b-b69f67dc2360} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50184) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f83d7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:42.854056 [ 1814 ] {53b0b6e6-b5c4-40b7-af4b-b69f67dc2360} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f83d7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30d8c5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:46.241166 [ 1534 ] {16d3f5fc-5bc6-4c46-9ccd-607876c2f7f0} executeQuery: Code: 43. DB::Exception: addMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' + interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b7ac9c5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b771a67 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:46.243240 [ 1534 ] {16d3f5fc-5bc6-4c46-9ccd-607876c2f7f0} TCPHandler: Code: 43. DB::Exception: addMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b7ac9c5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b771a67 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:47.077353 [ 1534 ] {a16b3ccb-3d3c-4afd-94a0-0057adde37da} executeQuery: Code: 43. DB::Exception: addMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' + interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b76e185 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b732c07 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:47.078679 [ 1534 ] {a16b3ccb-3d3c-4afd-94a0-0057adde37da} TCPHandler: Code: 43. DB::Exception: addMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b76e185 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b732c07 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:47.097612 [ 1534 ] {d4191a84-d40e-496b-816f-367a03513a61} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' + interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b86aca5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b82b187 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:47.098767 [ 1534 ] {d4191a84-d40e-496b-816f-367a03513a61} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b86aca5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b82b187 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:47.944272 [ 1534 ] {854e02f4-b78a-41af-808d-8b0b0c59d0d3} executeQuery: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' - interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c375e25 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c3392c7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:47.945684 [ 1534 ] {854e02f4-b78a-41af-808d-8b0b0c59d0d3} TCPHandler: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c375e25 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c3392c7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:48.756521 [ 1534 ] {adf5d746-adda-44ee-b3fa-7de423449924} executeQuery: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' - interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c3359e5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c2f8e87 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:48.758002 [ 1534 ] {adf5d746-adda-44ee-b3fa-7de423449924} TCPHandler: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c3359e5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c2f8e87 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:49.563651 [ 1534 ] {633f52eb-c22b-4d3b-959b-3e5c44afd1b2} executeQuery: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' - interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c432b65 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c3f4667 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:49.564994 [ 1534 ] {633f52eb-c22b-4d3b-959b-3e5c44afd1b2} TCPHandler: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c432b65 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c3f4667 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:50.409806 [ 1534 ] {d3673504-2574-433f-ae77-6c4198815ed8} executeQuery: Code: 43. DB::Exception: addMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') + interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b7ace85 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b771adf 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:50.411201 [ 1534 ] {d3673504-2574-433f-ae77-6c4198815ed8} TCPHandler: Code: 43. DB::Exception: addMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b7ace85 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b771adf 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:51.221114 [ 1534 ] {921f4896-c27d-48a1-9cd3-67a05e8d60ed} executeQuery: Code: 43. DB::Exception: addMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') + interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b76e645 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b732c7f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:51.222436 [ 1534 ] {921f4896-c27d-48a1-9cd3-67a05e8d60ed} TCPHandler: Code: 43. DB::Exception: addMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b76e645 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b732c7f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:51.723728 [ 1279 ] {} test_78p052s0.tableOut (7eb2cfb8-fda8-46b1-ba32-3c6b8d6951bf): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02916%2Ftest_78p052s0%2Ftable%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false&remote_fs_metadata=s3. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Could not exchange part all_1_1_0 as it's in preActive state (1000 ms) and it uses zero copy replication. This is expected behaviour and the client will retry fetching the part automatically. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:13:52.028521 [ 1534 ] {d4bf53cd-11a5-456e-b149-28832e59d905} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') + interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b86b165 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b82b1ff 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:52.029887 [ 1534 ] {d4bf53cd-11a5-456e-b149-28832e59d905} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000b86b165 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b82b1ff 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a458d3a 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019caaf99 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:52.876883 [ 1534 ] {5fd4f3e5-e3e2-4553-bd57-bc0105b46b3c} executeQuery: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') - interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c3762e5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c33933f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:52.878428 [ 1534 ] {5fd4f3e5-e3e2-4553-bd57-bc0105b46b3c} TCPHandler: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c3762e5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c33933f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:53.514168 [ 1276 ] {} test_78p052s0.tableOut (7eb2cfb8-fda8-46b1-ba32-3c6b8d6951bf): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02916%2Ftest_78p052s0%2Ftable%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false&remote_fs_metadata=s3. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Could not exchange part all_1_1_0 as it's in preActive state (1000 ms) and it uses zero copy replication. This is expected behaviour and the client will retry fetching the part automatically. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:13:53.688303 [ 1534 ] {b74a1bfc-a9c4-48fc-8cb2-4ce6c3c038ea} executeQuery: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') - interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c335ea5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c2f8eff 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:53.689685 [ 1534 ] {b74a1bfc-a9c4-48fc-8cb2-4ce6c3c038ea} TCPHandler: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c335ea5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c2f8eff 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:54.358357 [ 610 ] {f667f0c7-9df9-428c-b5db-29a5febde47c} executeQuery: Code: 117. DB::Exception: Line cannot be computed between start H3 index 72057594037927935 and end H3 index 72057594037927935: In scope SELECT h3Line(72057594037927935, 72057594037927935). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43648) (comment: 02293_h3_line.sql) (in query: SELECT h3Line(0xffffffffffffff, 0xffffffffffffff);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000001237f76d 4. DB::(anonymous namespace)::FunctionH3Line::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001237dd82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:13:54.359704 [ 610 ] {f667f0c7-9df9-428c-b5db-29a5febde47c} TCPHandler: Code: 117. DB::Exception: Line cannot be computed between start H3 index 72057594037927935 and end H3 index 72057594037927935: In scope SELECT h3Line(72057594037927935, 72057594037927935). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000001237f76d 4. DB::(anonymous namespace)::FunctionH3Line::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001237dd82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:13:54.498554 [ 1534 ] {157af4d4-9bfb-4373-9610-1b7e341c3192} executeQuery: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50242) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') - interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c433025 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c3f46df 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:54.499942 [ 1534 ] {157af4d4-9bfb-4373-9610-1b7e341c3192} TCPHandler: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001c433025 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c3f46df 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016c59ef4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001648e1f9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:13:54.959013 [ 1275 ] {} test_78p052s0.tableOut (7eb2cfb8-fda8-46b1-ba32-3c6b8d6951bf): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02916%2Ftest_78p052s0%2Ftable%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false&remote_fs_metadata=s3. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Could not exchange part all_1_1_0 as it's in preActive state (1000 ms) and it uses zero copy replication. This is expected behaviour and the client will retry fetching the part automatically. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:13:55.592098 [ 1583 ] {b0fe28dd-8803-44de-a50b-9667df5754f7} executeQuery: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43678) (comment: 01680_date_time_add_ubsan.sql) (in query: SELECT DISTINCT result FROM (SELECT toStartOfFifteenMinutes(toDateTime(toStartOfFifteenMinutes(toDateTime(1000.0001220703125) + (number * 65536))) + (number * 9223372036854775807)) AS result FROM system.numbers LIMIT 1048576) ORDER BY result DESC NULLS FIRST FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b8c79f3 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b8c4d54 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b8b1b97 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8adadf 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001a094f0b 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a091fc9 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:55.595778 [ 1583 ] {b0fe28dd-8803-44de-a50b-9667df5754f7} TCPHandler: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b8c79f3 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b8c4d54 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b8b1b97 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8adadf 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001a094f0b 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a091fc9 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:55.724248 [ 1588 ] {f56ae1e7-1a34-4881-a26f-16c6e70a11c2} executeQuery: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: -- test what should not work CREATE TABLE codecs (a UInt8 CODEC(NONE, NONE)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491deb5 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:55.725753 [ 1588 ] {f56ae1e7-1a34-4881-a26f-16c6e70a11c2} TCPHandler: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491deb5 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:55.741758 [ 1588 ] {1027b4b9-10b8-4754-87e9-1fd480f9fa6f} executeQuery: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(NONE, LZ4)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491deb5 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:55.743254 [ 1588 ] {1027b4b9-10b8-4754-87e9-1fd480f9fa6f} TCPHandler: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491deb5 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:55.759739 [ 1588 ] {7ed439ae-6d6f-4bd4-8e09-138528b86373} executeQuery: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: LZ4, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, NONE)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491deb5 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:55.761349 [ 1588 ] {7ed439ae-6d6f-4bd4-8e09-138528b86373} TCPHandler: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: LZ4, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491deb5 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.198792 [ 1588 ] {a3c84476-1769-488e-a73f-f0cfc38918ee} executeQuery: Code: 36. DB::Exception: The combination of compression codecs LZ4, LZ4 is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, LZ4)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e3eb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.200202 [ 1588 ] {a3c84476-1769-488e-a73f-f0cfc38918ee} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs LZ4, LZ4 is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e3eb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.214937 [ 1588 ] {6dfe9004-1fa0-4749-a30d-ef1deec3bc9b} executeQuery: Code: 36. DB::Exception: The combination of compression codecs LZ4, ZSTD(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, ZSTD)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e3eb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.215820 [ 1588 ] {6dfe9004-1fa0-4749-a30d-ef1deec3bc9b} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs LZ4, ZSTD(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e3eb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.649116 [ 1588 ] {b7821a1f-65df-47f5-afba-77aa5aee08cb} executeQuery: Code: 36. DB::Exception: Compression codec Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(Delta)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e003 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.650502 [ 1588 ] {b7821a1f-65df-47f5-afba-77aa5aee08cb} TCPHandler: Code: 36. DB::Exception: Compression codec Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e003 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.664168 [ 1588 ] {375770a4-dcb1-4a62-886a-f29f4b149917} executeQuery: Code: 36. DB::Exception: Compression codec Delta(1), Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(Delta, Delta)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e003 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.665207 [ 1588 ] {375770a4-dcb1-4a62-886a-f29f4b149917} TCPHandler: Code: 36. DB::Exception: Compression codec Delta(1), Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e003 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.675494 [ 1588 ] {85c2c517-39c6-4a3d-8d61-090ed9df02a0} executeQuery: Code: 36. DB::Exception: The combination of compression codecs LZ4, Delta(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, Delta)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e3eb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.676268 [ 1588 ] {85c2c517-39c6-4a3d-8d61-090ed9df02a0} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs LZ4, Delta(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e3eb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:56.849275 [ 1273 ] {} test_78p052s0.tableOut (7eb2cfb8-fda8-46b1-ba32-3c6b8d6951bf): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02916%2Ftest_78p052s0%2Ftable%2Freplicas%2F1&part=all_2_2_0&client_protocol_version=8&compress=false&remote_fs_metadata=s3. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Could not exchange part all_2_2_0 as it's in preActive state (1000 ms) and it uses zero copy replication. This is expected behaviour and the client will retry fetching the part automatically. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:13:57.096257 [ 1588 ] {8d001ce3-f412-4878-95b8-1d9a97c19fad} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e53b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.097718 [ 1588 ] {8d001ce3-f412-4878-95b8-1d9a97c19fad} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e53b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.113033 [ 1588 ] {1f51ce49-aa8b-4eae-9135-4d64df65880d} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a FixedString(2) CODEC(Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e53b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.114352 [ 1588 ] {1f51ce49-aa8b-4eae-9135-4d64df65880d} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e53b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.127566 [ 1588 ] {5c5846f9-032d-490c-8744-189c2dfd5e60} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a Decimal(15,5) CODEC(Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e53b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.128821 [ 1588 ] {5c5846f9-032d-490c-8744-189c2dfd5e60} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e53b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.550301 [ 1588 ] {deec9253-2fb8-407d-9b70-862cd1d1786b} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Delta(8), Gorilla is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a Float64 CODEC(Delta, Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e2a0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.551725 [ 1588 ] {deec9253-2fb8-407d-9b70-862cd1d1786b} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Delta(8), Gorilla is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e2a0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.566850 [ 1588 ] {29029598-d86e-4d02-a9a5-68876286ff07} executeQuery: Code: 36. DB::Exception: The combination of compression codecs DoubleDelta, FPC(12) is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43698) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a Float32 CODEC(DoubleDelta, FPC)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e2a0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:57.568346 [ 1588 ] {29029598-d86e-4d02-a9a5-68876286ff07} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs DoubleDelta, FPC(12) is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491e2a0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489b339 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:13:58.724349 [ 1272 ] {} test_78p052s0.tableOut (7eb2cfb8-fda8-46b1-ba32-3c6b8d6951bf): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02916%2Ftest_78p052s0%2Ftable%2Freplicas%2F1&part=all_2_2_0&client_protocol_version=8&compress=false&remote_fs_metadata=s3. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Could not exchange part all_2_2_0 as it's in preActive state (1000 ms) and it uses zero copy replication. This is expected behaviour and the client will retry fetching the part automatically. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:14:00.194293 [ 1271 ] {} test_78p052s0.tableOut (7eb2cfb8-fda8-46b1-ba32-3c6b8d6951bf): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02916%2Ftest_78p052s0%2Ftable%2Freplicas%2F1&part=all_2_2_0&client_protocol_version=8&compress=false&remote_fs_metadata=s3. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Could not exchange part all_2_2_0 as it's in preActive state (1000 ms) and it uses zero copy replication. This is expected behaviour and the client will retry fetching the part automatically. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:14:01.291674 [ 610 ] {82b74550-443c-434d-9177-5818d7d1b907} executeQuery: Code: 572. DB::Exception: Too many optimizations applied to query plan. Current limit 1. (TOO_MANY_QUERY_PLAN_OPTIMIZATIONS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43748) (comment: 01655_plan_optimizations.sh) (in query: select x + 1 from (select y + 2 as x from (select dummy + 3 as y)) settings query_plan_max_optimizations_to_apply = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:83: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c0fa218 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:506: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaa0 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:01.294235 [ 610 ] {82b74550-443c-434d-9177-5818d7d1b907} TCPHandler: Code: 572. DB::Exception: Too many optimizations applied to query plan. Current limit 1. (TOO_MANY_QUERY_PLAN_OPTIMIZATIONS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:83: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c0fa218 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:506: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaa0 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:01.483516 [ 1534 ] {6849a3e2-024f-4b73-aa8a-f3e855ef843a} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1205829499152117266_2948901123380374598 :: 1) -> nullIn(__table1.str, __set_1205829499152117266_2948901123380374598) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43728) (comment: 01681_bloom_filter_nullable_column.sql) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860748d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350d248c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef0a6a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbabc8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb0f72 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf55eb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:01.487609 [ 1534 ] {6849a3e2-024f-4b73-aa8a-f3e855ef843a} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1205829499152117266_2948901123380374598 :: 1) -> nullIn(__table1.str, __set_1205829499152117266_2948901123380374598) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860748d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350d248c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef0a6a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbabc8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb0f72 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf55eb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:01.569958 [ 1534 ] {67b0578e-22c8-4ba8-b139-592282ade69e} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1205829499152117266_2948901123380374598 :: 1) -> nullIn(__table1.str, __set_1205829499152117266_2948901123380374598) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43728) (comment: 01681_bloom_filter_nullable_column.sql) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860748d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350d248c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef0a6a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbabc8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb0f72 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf55eb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:01.572780 [ 1534 ] {67b0578e-22c8-4ba8-b139-592282ade69e} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1205829499152117266_2948901123380374598 :: 1) -> nullIn(__table1.str, __set_1205829499152117266_2948901123380374598) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860748d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350d248c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef0a6a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cbabc8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4ac2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb0f72 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf55eb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:04.256195 [ 1534 ] {a9bfbef8-c66a-4bf6-b7c3-87ab81561b82} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '0b' in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54130) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:04.258698 [ 1534 ] {a9bfbef8-c66a-4bf6-b7c3-87ab81561b82} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '0b' in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:04.891815 [ 1534 ] {82e2e201-e929-4536-8e74-64fb1ead1f0e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '0b' in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54140) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:04.894308 [ 1534 ] {82e2e201-e929-4536-8e74-64fb1ead1f0e} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '0b' in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:05.562694 [ 1588 ] {538ac49a-b85b-48ab-bea7-a5f550b4ec87} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '0b' in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54170) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0b ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:05.565032 [ 1588 ] {538ac49a-b85b-48ab-bea7-a5f550b4ec87} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '0b' in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:06.198331 [ 1588 ] {722d3ecc-8f8e-4886-b387-68d21cdf2c98} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '0x' in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54208) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0x), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:06.201107 [ 1588 ] {722d3ecc-8f8e-4886-b387-68d21cdf2c98} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '0x' in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:06.849729 [ 16275 ] {51989dd5-1cb3-44ec-b779-4925cbeefa6c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '0x' in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54246) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:06.852410 [ 16275 ] {51989dd5-1cb3-44ec-b779-4925cbeefa6c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '0x' in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:07.504368 [ 1534 ] {50017719-0932-4cb1-aaea-232232b089cd} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '0x' in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54254) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0x ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:07.507118 [ 1534 ] {50017719-0932-4cb1-aaea-232232b089cd} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '0x' in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:07.703034 [ 610 ] {c9b5b50d-baa6-4729-a47b-8bc4cc51a002} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2299, 12, 31, 23, 59, 59, 999999999, 9, 'UTC'). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54196) (comment: 02245_make_datetime64.sql) (in query: select makeDateTime64(2299, 12, 31, 23, 59, 59, 999999999, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008674592 5. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f9eef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:14:07.704342 [ 610 ] {c9b5b50d-baa6-4729-a47b-8bc4cc51a002} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2299, 12, 31, 23, 59, 59, 999999999, 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008674592 5. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f9eef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:14:08.526793 [ 610 ] {17dae22b-b448-4e23-9a11-14cc56a3cf83} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2262, 4, 11, 23, 47, 16, 854775808, 9, 'UTC'). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54196) (comment: 02245_make_datetime64.sql) (in query: select makeDateTime64(2262, 4, 11, 23, 47, 16, 854775808, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x00000000086746da 5. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f9eef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:14:08.528135 [ 610 ] {17dae22b-b448-4e23-9a11-14cc56a3cf83} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2262, 4, 11, 23, 47, 16, 854775808, 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x00000000086746da 5. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f9eef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:14:09.630987 [ 610 ] {2457a64e-8425-4d1c-8128-19604437a0b7} executeQuery: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, 10, 'CET'). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54196) (comment: 02245_make_datetime64.sql) (in query: select makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, 10, 'CET');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x0000000015fa0c79 5. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f9feef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:09.632408 [ 610 ] {2457a64e-8425-4d1c-8128-19604437a0b7} TCPHandler: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, 10, 'CET'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x0000000015fa0c79 5. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f9feef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:09.650010 [ 610 ] {e26757bd-6cc8-4e4a-8fe7-5c627f1e520c} executeQuery: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, -1, 'CET'). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54196) (comment: 02245_make_datetime64.sql) (in query: select makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, -1, 'CET');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x0000000015fa0c79 5. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f9feef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:09.651200 [ 610 ] {e26757bd-6cc8-4e4a-8fe7-5c627f1e520c} TCPHandler: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, -1, 'CET'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x0000000015fa0c79 5. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f9feef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:10.484690 [ 16275 ] {ee0a19d0-1c9c-4e53-be33-b27d7f9a12fb} executeQuery: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_a9eaaae9-bcf4-4c0c-927c-d0fdf6c2b1e0` (a9eaaae9-bcf4-4c0c-927c-d0fdf6c2b1e0) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54424) (comment: 01358_constexpr_constraint.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:10.487934 [ 16275 ] {ee0a19d0-1c9c-4e53-be33-b27d7f9a12fb} TCPHandler: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_a9eaaae9-bcf4-4c0c-927c-d0fdf6c2b1e0` (a9eaaae9-bcf4-4c0c-927c-d0fdf6c2b1e0) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:10.579565 [ 610 ] {975b9376-b293-4e57-b80b-4cf852d48999} executeQuery: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime64(1984, 1, 1, 0, 0, 0, 0, 9, 'not a timezone'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54196) (comment: 02245_make_datetime64.sql) (in query: select makeDateTime64(1984, 1, 1, 0, 0, 0, 0, 9, 'not a timezone');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe4c87 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd5f16 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032370d1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032371932 8. std::shared_ptr std::allocate_shared[abi:v15007], long&, String&, void>(std::allocator const&, long&, String&) @ 0x0000000015fa979b 9. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa0137 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:10.581259 [ 610 ] {975b9376-b293-4e57-b80b-4cf852d48999} TCPHandler: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime64(1984, 1, 1, 0, 0, 0, 0, 9, 'not a timezone'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe4c87 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd5f16 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032370d1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032371932 8. std::shared_ptr std::allocate_shared[abi:v15007], long&, String&, void>(std::allocator const&, long&, String&) @ 0x0000000015fa979b 9. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa0137 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:12.714866 [ 610 ] {6eaadf81-f125-46a8-9db5-bc3fde509513} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 7th argument 'precision' to function 'makeDateTime64'. Expected: const Number, got: UInt8: In scope SELECT makeDateTime64(year, 1, 1, 1, 0, 0, 0, precision, timezone) FROM (SELECT 1984 AS year, 5 AS precision, 'UTC' AS timezone UNION ALL SELECT 1985 AS year, 5 AS precision, 'UTC' AS timezone). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54196) (comment: 02245_make_datetime64.sql) (in query: select makeDateTime64(year, 1, 1, 1, 0, 0, 0, precision, timezone) from ( select 1984 as year, 5 as precision, 'UTC' as timezone union all select 1985 as year, 5 as precision, 'UTC' as timezone );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f9fcb2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:14:12.717203 [ 610 ] {6eaadf81-f125-46a8-9db5-bc3fde509513} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 7th argument 'precision' to function 'makeDateTime64'. Expected: const Number, got: UInt8: In scope SELECT makeDateTime64(year, 1, 1, 1, 0, 0, 0, precision, timezone) FROM (SELECT 1984 AS year, 5 AS precision, 'UTC' AS timezone UNION ALL SELECT 1985 AS year, 5 AS precision, 'UTC' AS timezone). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f9fcb2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:14:13.112147 [ 3810 ] {01170_alter_partition_isolation_test_dgg43e41_tx3_12144} executeQuery: Code: 650. DB::Exception: Serialization error: Transaction (41, 36, 92427cc0-299d-4553-b6c7-a452802d57ca) tried to remove data part all_4_4_0 from test_dgg43e41.mt (509730ca-9392-4088-a04f-e287d25c0afb), but it's locked by another transaction (TID: (41, 33, 92427cc0-299d-4553-b6c7-a452802d57ca), TIDH: 7076142063435420371) which is currently removing this part. (SERIALIZATION_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42190) (in query: alter table mt drop partition id 'all'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x00000000356074e7 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:62: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x00000000355ff052 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000034f4a463 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000034f4a19c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x0000000039785ef9 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a33591d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5309: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d07d6 10. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 14. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:13.115112 [ 3810 ] {01170_alter_partition_isolation_test_dgg43e41_tx3_12144} DynamicQueryHandler: Code: 650. DB::Exception: Serialization error: Transaction (41, 36, 92427cc0-299d-4553-b6c7-a452802d57ca) tried to remove data part all_4_4_0 from test_dgg43e41.mt (509730ca-9392-4088-a04f-e287d25c0afb), but it's locked by another transaction (TID: (41, 33, 92427cc0-299d-4553-b6c7-a452802d57ca), TIDH: 7076142063435420371) which is currently removing this part. (SERIALIZATION_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x00000000356074e7 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:62: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x00000000355ff052 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000034f4a463 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000034f4a19c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x0000000039785ef9 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a33591d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5309: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d07d6 10. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 14. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:14:13.142810 [ 3810 ] {01170_alter_partition_isolation_test_dgg43e41_tx3_17806} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42198) (in query: insert into mt values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/executeQuery.cpp:914: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac6ae 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:13.146532 [ 3810 ] {01170_alter_partition_isolation_test_dgg43e41_tx3_17806} DynamicQueryHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/executeQuery.cpp:914: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac6ae 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:14:16.323026 [ 16278 ] {48281a5c-5b06-496e-a7eb-598be02a881f} executeQuery: Code: 479. DB::Exception: Unknown disk name __un_exists_disk while execute function filesystemCapacity: In scope SELECT filesystemCapacity('__un_exists_disk'). (UNKNOWN_DISK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57718) (comment: 02457_filesystem_function.sql) (in query: select filesystemCapacity('__un_exists_disk');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. DB::(anonymous namespace)::FilesystemImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f97b674 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:14:16.324386 [ 16278 ] {48281a5c-5b06-496e-a7eb-598be02a881f} TCPHandler: Code: 479. DB::Exception: Unknown disk name __un_exists_disk while execute function filesystemCapacity: In scope SELECT filesystemCapacity('__un_exists_disk'). (UNKNOWN_DISK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. DB::(anonymous namespace)::FilesystemImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f97b674 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:14:17.809822 [ 610 ] {31764fdb-897a-456e-95e9-6f83880ff61a} executeQuery: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: -- { echoOff } SELECT sparkbar(0)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f785c62 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:17.811561 [ 610 ] {31764fdb-897a-456e-95e9-6f83880ff61a} TCPHandler: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f785c62 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:17.833062 [ 610 ] {ee15c633-41a5-43a2-8063-0610f75386a7} executeQuery: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(1)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f785c62 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:17.834692 [ 610 ] {ee15c633-41a5-43a2-8063-0610f75386a7} TCPHandler: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f785c62 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:17.854736 [ 610 ] {0b9f8198-b706-49e1-910a-09389a200a20} executeQuery: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(1025)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f785c62 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:17.856123 [ 610 ] {0b9f8198-b706-49e1-910a-09389a200a20} TCPHandler: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f785c62 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:18.526910 [ 610 ] {ae15eb7d-1b26-4b3d-8127-d040905df143} executeQuery: Code: 36. DB::Exception: Parameter `min_x` must be less than `max_x`. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(2, 10, 9)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f76d928 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:18.528377 [ 610 ] {ae15eb7d-1b26-4b3d-8127-d040905df143} TCPHandler: Code: 36. DB::Exception: Parameter `min_x` must be less than `max_x`. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f76d928 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:19.183303 [ 610 ] {7f5eae09-d042-4d8e-8012-7e1c89639fdc} executeQuery: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(2, -5, -1)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741e65 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:19.185274 [ 610 ] {7f5eae09-d042-4d8e-8012-7e1c89639fdc} TCPHandler: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741e65 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:19.213351 [ 610 ] {862b781d-51a9-4198-b7df-963098a64b00} executeQuery: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(2, -5, 1)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741e65 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:19.215255 [ 610 ] {862b781d-51a9-4198-b7df-963098a64b00} TCPHandler: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741e65 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:19.825345 [ 16275 ] {30461a6a-2920-413d-87f3-86d2caa495cd} executeQuery: Code: 43. DB::Exception: Function toStartOfDay supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfDay(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfDay(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c6c92c1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:19.827076 [ 16275 ] {30461a6a-2920-413d-87f3-86d2caa495cd} TCPHandler: Code: 43. DB::Exception: Function toStartOfDay supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfDay(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c6c92c1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:19.987283 [ 610 ] {8080cdd3-970b-426b-91d1-68877e191f90} executeQuery: Code: 43. DB::Exception: The first argument type must be UInt or Date or DateTime for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(2)(toInt32(number), number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:339: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f783d5b 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:20.012224 [ 610 ] {8080cdd3-970b-426b-91d1-68877e191f90} TCPHandler: Code: 43. DB::Exception: The first argument type must be UInt or Date or DateTime for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:339: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x000000002f783d5b 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:0: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f7416b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:20.662112 [ 610 ] {d65bbf93-fc2c-464f-b825-e866cd43b0c0} executeQuery: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(2, 0)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741ce7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:20.663568 [ 610 ] {d65bbf93-fc2c-464f-b825-e866cd43b0c0} TCPHandler: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741ce7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:20.684081 [ 610 ] {78d4c879-6b55-4f29-9c81-2df29834c809} executeQuery: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 4. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57682) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(2, 0, 5, 8)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741ce7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:20.685466 [ 610 ] {78d4c879-6b55-4f29-9c81-2df29834c809} TCPHandler: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 4. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f741ce7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:20.736249 [ 1588 ] {3cffd268-1cca-4358-a5c5-ae002e03b1ac} executeQuery: Code: 47. DB::Exception: Identifier 'l.c' cannot be resolved from subquery with name l. In scope SELECT l.c FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['l.a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57884) (comment: 01034_unknown_qualified_column_in_join.sql) (in query: SELECT l.c FROM (SELECT 1 AS a, 2 AS b) AS l join (SELECT 2 AS b, 3 AS c) AS r USING b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000335c949f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335b0f74 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b45e6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb078 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b6604 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:20.738428 [ 1588 ] {3cffd268-1cca-4358-a5c5-ae002e03b1ac} TCPHandler: Code: 47. DB::Exception: Identifier 'l.c' cannot be resolved from subquery with name l. In scope SELECT l.c FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['l.a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000335c949f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335b0f74 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b45e6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb078 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b6604 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:20.773092 [ 16275 ] {593b1b5a-adb1-45a3-a973-4d407347e796} executeQuery: Code: 43. DB::Exception: Function toMonday supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toMonday(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toMonday(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c66ac02 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:20.774880 [ 16275 ] {593b1b5a-adb1-45a3-a973-4d407347e796} TCPHandler: Code: 43. DB::Exception: Function toMonday supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toMonday(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c66ac02 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:21.440211 [ 1588 ] {f2eca0a4-f7a2-478c-bb5c-c7043cef69e3} executeQuery: Code: 47. DB::Exception: Identifier 'r.a' cannot be resolved from subquery with name r. In scope SELECT r.a FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['r.b']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57884) (comment: 01034_unknown_qualified_column_in_join.sql) (in query: SELECT r.a FROM (SELECT 1 AS a, 2 AS b) AS l join (SELECT 2 AS b, 3 AS c) AS r USING b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000335c949f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335b0f74 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b45e6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb078 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b66e5 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:21.441912 [ 1588 ] {f2eca0a4-f7a2-478c-bb5c-c7043cef69e3} TCPHandler: Code: 47. DB::Exception: Identifier 'r.a' cannot be resolved from subquery with name r. In scope SELECT r.a FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['r.b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000335c949f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335b0f74 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b45e6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb078 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b66e5 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335bb0aa 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335c2227 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476cdd 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:21.614423 [ 16275 ] {ef87a10b-889c-4163-94b5-8220fd59f8ab} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x000000001c5c11da 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bc77f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:21.616177 [ 16275 ] {ef87a10b-889c-4163-94b5-8220fd59f8ab} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x000000001c5c11da 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bc77f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:21.672721 [ 16275 ] {032bf990-21ad-48f0-9dc0-10b5a024c6dd} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x000000001c5c11da 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bc77f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:21.674047 [ 16275 ] {032bf990-21ad-48f0-9dc0-10b5a024c6dd} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x000000001c5c11da 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bc77f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:22.502748 [ 16275 ] {62ec076a-8699-49fd-8333-04de16bf1470} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x000000001c5cc71a 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5c829f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:22.504450 [ 16275 ] {62ec076a-8699-49fd-8333-04de16bf1470} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x000000001c5cc71a 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5c829f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:22.554478 [ 16275 ] {7d733967-cb27-4574-8688-36c25daf3f23} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x000000001c5cc71a 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5c829f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:22.555773 [ 16275 ] {7d733967-cb27-4574-8688-36c25daf3f23} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000f956846 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x000000001c5cc71a 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5c829f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:23.312185 [ 16275 ] {6337d76b-ab3a-4734-bc3c-ba167bfa6344} executeQuery: Code: 43. DB::Exception: Function toStartOfMonth supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMonth(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfMonth(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c7187e2 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:23.313618 [ 16275 ] {6337d76b-ab3a-4734-bc3c-ba167bfa6344} TCPHandler: Code: 43. DB::Exception: Function toStartOfMonth supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMonth(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c7187e2 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:23.828864 [ 16278 ] {7251d358-8c0f-4183-ad14-e7616bcf2e8a} executeQuery: Code: 417. DB::Exception: Expected ANY or ALL in JOIN section, because setting (join_default_strictness) is empty. (EXPECTED_ALL_OR_ANY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52028) (comment: 00742_require_join_strictness.sql) (in query: SELECT * FROM system.one INNER JOIN (SELECT number AS k FROM system.numbers) js2 ON dummy = k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a1900 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003337efca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333897a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003337ee2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003337d95c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce1bf0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:23.830727 [ 16278 ] {7251d358-8c0f-4183-ad14-e7616bcf2e8a} TCPHandler: Code: 417. DB::Exception: Expected ANY or ALL in JOIN section, because setting (join_default_strictness) is empty. (EXPECTED_ALL_OR_ANY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a1900 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003337efca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333897a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003337ee2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003337d95c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce1bf0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:24.075942 [ 16275 ] {125ffe59-b6ea-4521-8b22-211a9d62de64} executeQuery: Code: 43. DB::Exception: Function toStartOfQuarter supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfQuarter(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfQuarter(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c722662 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:24.077294 [ 16275 ] {125ffe59-b6ea-4521-8b22-211a9d62de64} TCPHandler: Code: 43. DB::Exception: Function toStartOfQuarter supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfQuarter(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c722662 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:24.833048 [ 16275 ] {e1703f7a-b4d2-4e89-ae92-42376b09da11} executeQuery: Code: 43. DB::Exception: Function toStartOfYear supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfYear(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfYear(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c750882 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:24.834454 [ 16275 ] {e1703f7a-b4d2-4e89-ae92-42376b09da11} TCPHandler: Code: 43. DB::Exception: Function toStartOfYear supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfYear(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c750882 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:25.611035 [ 16275 ] {620ba28c-98a2-4958-9b50-4203f6dc8e93} executeQuery: Code: 43. DB::Exception: Function toStartOfTenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfTenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfTenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c746ec1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:25.612443 [ 16275 ] {620ba28c-98a2-4958-9b50-4203f6dc8e93} TCPHandler: Code: 43. DB::Exception: Function toStartOfTenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfTenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c746ec1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:26.069216 [ 16279 ] {d14f84ac-0c7b-4d2f-b7b5-ff2a384be83a} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52104) (comment: 03095_msan_uuid_string_to_num.sql) (in query: SELECT UUIDStringToNum('00112233-4455-6677-8899-aabbccddeeff', materialize(2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:26.070683 [ 16279 ] {d14f84ac-0c7b-4d2f-b7b5-ff2a384be83a} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:26.136847 [ 16279 ] {efa18655-4806-474a-8003-962f054c5286} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52104) (comment: 03095_msan_uuid_string_to_num.sql) (in query: SELECT 'a/<@];!~p{jTj={)' AS bytes, UUIDNumToString(toFixedString(bytes, 16), materialize(2)) AS uuid;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:26.138335 [ 16279 ] {efa18655-4806-474a-8003-962f054c5286} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:26.389506 [ 16275 ] {588bcb01-0f90-4eca-ae69-b352c0a0a9d1} executeQuery: Code: 43. DB::Exception: Function toStartOfFifteenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfFifteenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfFifteenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c6d34e1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:26.391249 [ 16275 ] {588bcb01-0f90-4eca-ae69-b352c0a0a9d1} TCPHandler: Code: 43. DB::Exception: Function toStartOfFifteenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfFifteenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c6d34e1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:26.739900 [ 1534 ] {d0f4aec0-a68a-402e-bf60-94ebbf7ab2f2} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57936) (comment: 00700_decimal_aggregates.sql) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6e9a57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d37510a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:26.741627 [ 1534 ] {d0f4aec0-a68a-402e-bf60-94ebbf7ab2f2} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6e9a57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d37510a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:27.194387 [ 16275 ] {773deed9-bc6c-4eb8-ac02-ea1a5fb535a3} executeQuery: Code: 43. DB::Exception: Function toStartOfHour supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfHour(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfHour(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c6e6921 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:27.195899 [ 16275 ] {773deed9-bc6c-4eb8-ac02-ea1a5fb535a3} TCPHandler: Code: 43. DB::Exception: Function toStartOfHour supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfHour(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c6e6921 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:27.594349 [ 1534 ] {df02f38e-7394-477e-9054-3741d3acc9ad} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57936) (comment: 00700_decimal_aggregates.sql) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6e9a57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d3744aa 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:27.595859 [ 1534 ] {df02f38e-7394-477e-9054-3741d3acc9ad} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6e9a57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d3744aa 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:27.967057 [ 16275 ] {21b91855-b037-443c-88de-8e66c121e2b0} executeQuery: Code: 43. DB::Exception: Function toStartOfMinute supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMinute(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57828) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfMinute(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c70ee21 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:27.968372 [ 16275 ] {21b91855-b037-443c-88de-8e66c121e2b0} TCPHandler: Code: 43. DB::Exception: Function toStartOfMinute supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMinute(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c70ee21 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:14:28.455702 [ 1534 ] {3c0c40c4-fc9f-4be2-a28f-226a0e997e5e} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57936) (comment: 00700_decimal_aggregates.sql) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6e9a57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d66792f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:28.457345 [ 1534 ] {3c0c40c4-fc9f-4be2-a28f-226a0e997e5e} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6e9a57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d66792f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:29.747688 [ 610 ] {2dbb91b1-6a1f-4150-a2d8-3d512cfb13dc} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 136. Bytes expected: 1919379265.: In scope SELECT finalizeAggregation(CAST('AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)', 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52156) (comment: 02481_i43247_ubsan_in_minmaxany.sql) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/43247 SELECT finalizeAggregation(CAST('AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)', 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0df8c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002cebd88f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:14:29.749199 [ 610 ] {2dbb91b1-6a1f-4150-a2d8-3d512cfb13dc} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 136. Bytes expected: 1919379265.: In scope SELECT finalizeAggregation(CAST('AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)', 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0df8c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002cebd88f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:14:31.124262 [ 31332 ] {3cbe8432-75a4-4113-9c0f-9d8b4e811a91} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52210) (comment: 02456_bloom_filter_assert.gen.sql) (in query: SELECT count() FROM bftest__fuzz_21 WHERE hasAll(x, [42, -42]) SETTINGS use_skip_indexes=1, force_data_skipping_indices='ix1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:31.125863 [ 31332 ] {3cbe8432-75a4-4113-9c0f-9d8b4e811a91} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:31.175896 [ 1402 ] {b1017474-eafc-4362-8471-a845f13dd083} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_q75hwhsj.t_async_insert_bad_data FORMAT Values' with query id 06e57559-3567-4837-b7f0-1f664624c976. DB::Exception: Cannot parse expression of type String here: 'bad'string') 2025.06.18 11:14:31.435807 [ 31332 ] {684b9952-15e4-4f24-b06a-7d10dd5f17fd} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52210) (comment: 02456_bloom_filter_assert.gen.sql) (in query: SELECT count() FROM bftest__fuzz_21 WHERE hasAll(x, [42, -42]) SETTINGS use_skip_indexes=1, force_data_skipping_indices='ix1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:31.437571 [ 31332 ] {684b9952-15e4-4f24-b06a-7d10dd5f17fd} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:31.539787 [ 16279 ] {06e57559-3567-4837-b7f0-1f664624c976} executeQuery: Code: 62. DB::Exception: Cannot parse expression of type String here: 'bad'string'): While executing WaitForAsyncInsert. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34146) (comment: 02563_async_insert_bad_data.sh) (in query: INSERT INTO t_async_insert_bad_data VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity>>::type>, String&&, std::basic_string_view>&&) @ 0x000000001c70b84d 4. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:434: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x000000003b6de561 5. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x000000003b6d7dba 6. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::read() @ 0x000000003b6d4603 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:31.542756 [ 16279 ] {06e57559-3567-4837-b7f0-1f664624c976} DynamicQueryHandler: Code: 62. DB::Exception: Cannot parse expression of type String here: 'bad'string'): While executing WaitForAsyncInsert. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity>>::type>, String&&, std::basic_string_view>&&) @ 0x000000001c70b84d 4. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:434: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x000000003b6de561 5. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x000000003b6d7dba 6. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::read() @ 0x000000003b6d4603 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:14:31.759891 [ 31332 ] {3c75e117-1845-4c7c-ae9d-8399d3d65e3f} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52210) (comment: 02456_bloom_filter_assert.gen.sql) (in query: SELECT count() FROM bftest__fuzz_21 WHERE hasAll(x, [42, -42]) SETTINGS use_skip_indexes=1, force_data_skipping_indices='ix1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:31.761452 [ 31332 ] {3c75e117-1845-4c7c-ae9d-8399d3d65e3f} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a44cc2 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf00969 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:35.346130 [ 16278 ] {f6c145c8-bf72-47fc-8a34-d5a40b7e7f1b} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49470) (comment: 01666_lcm_ubsan.sql) (in query: -- { echo } SELECT lcm(9223372036854775807, -9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000140e45a0 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000141f3cb5 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000014170cad 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:35.348102 [ 16278 ] {f6c145c8-bf72-47fc-8a34-d5a40b7e7f1b} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000140e45a0 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000141f3cb5 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000014170cad 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:35.367065 [ 16278 ] {81ec334b-9747-4bb2-9d94-bddcc69c46ed} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49470) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(9223372036854775808, -9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000140e45a0 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000141f3cb5 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000014170cad 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:35.368570 [ 16278 ] {81ec334b-9747-4bb2-9d94-bddcc69c46ed} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000140e45a0 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000141f3cb5 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000014170cad 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:36.209004 [ 16278 ] {298e4d0b-c387-46f7-bfb1-708d53622666} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49470) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(-9223372036854775808, 9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001412d820 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001429f455 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001417160d 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:36.210435 [ 16278 ] {298e4d0b-c387-46f7-bfb1-708d53622666} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001412d820 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001429f455 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001417160d 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:36.228517 [ 16278 ] {d7e6806e-d661-4339-898f-90e3c5bd1ae8} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49470) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(-9223372036854775807, 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001412d820 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001429f455 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001417160d 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:36.230064 [ 16278 ] {d7e6806e-d661-4339-898f-90e3c5bd1ae8} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001412d820 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001429f455 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001417160d 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:36.770092 [ 610 ] {ca9f47c1-e27a-4edb-a41a-9a97a84f2469} executeQuery: Code: 36. DB::Exception: Last argument (count) for function widthBucket cannot be 0.: while executing 'FUNCTION widthBucket(__table1.operand :: 0, __table1.low :: 1, __table1.high :: 2, __table1.count : 3) -> widthBucket(__table1.operand, __table1.low, __table1.high, __table1.count) UInt64 : 7'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: -- zero is not valid for count SELECT operand, low, high, count, WIDTH_BUCKET(operand, low, high, count) FROM mytable WHERE count = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, unsigned long) const @ 0x000000001cb2f68c 5. unsigned long DB::FunctionWidthBucket::calculate(double, double, double, unsigned long) const @ 0x000000001cb2f05a 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEmEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb2a99e 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c22e 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:36.773556 [ 610 ] {ca9f47c1-e27a-4edb-a41a-9a97a84f2469} TCPHandler: Code: 36. DB::Exception: Last argument (count) for function widthBucket cannot be 0.: while executing 'FUNCTION widthBucket(__table1.operand :: 0, __table1.low :: 1, __table1.high :: 2, __table1.count : 3) -> widthBucket(__table1.operand, __table1.low, __table1.high, __table1.count) UInt64 : 7'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, unsigned long) const @ 0x000000001cb2f68c 5. unsigned long DB::FunctionWidthBucket::calculate(double, double, double, unsigned long) const @ 0x000000001cb2f05a 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEmEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb2a99e 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c22e 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:37.081314 [ 16278 ] {f8ff2861-a7d7-4a58-8c36-4fe87ed0086a} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -1). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49470) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(9223372036854775808, -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::LCMImpl::NameLCM>::apply(unsigned long, DB::(anonymous namespace)) @ 0x00000000140e20fa 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000141ee536 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000014170cad 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.083137 [ 16278 ] {f8ff2861-a7d7-4a58-8c36-4fe87ed0086a} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -1). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf4f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::LCMImpl::NameLCM>::apply(unsigned long, DB::(anonymous namespace)) @ 0x00000000140e20fa 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000141ee536 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000014170cad 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001416117b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415d408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014159abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.340111 [ 16275 ] {aac36b3f-8a85-4e2c-8b7b-7d003bd949e5} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 100.00 billion, current rows: 1.00 trillion. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49576) (comment: 03024_total_rows_approx_is_set_for_system_zeros_and_generate_random.sql) (in query: SELECT * FROM system.numbers LIMIT 1e12 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:37.341670 [ 16275 ] {aac36b3f-8a85-4e2c-8b7b-7d003bd949e5} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 100.00 billion, current rows: 1.00 trillion. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:37.367528 [ 16275 ] {7738fd2a-6c74-4f5c-b9e7-10f22e3751bd} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 100.00 billion, current rows: 1.00 trillion. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49576) (comment: 03024_total_rows_approx_is_set_for_system_zeros_and_generate_random.sql) (in query: SELECT * FROM system.numbers_mt LIMIT 1e12 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:37.368844 [ 16275 ] {7738fd2a-6c74-4f5c-b9e7-10f22e3751bd} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 100.00 billion, current rows: 1.00 trillion. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:37.590955 [ 610 ] {cb38da7c-2e0c-4369-ab13-d078730d4e48} executeQuery: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, 10, nan, 10). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: -- operand, low and high cannot be NaN SELECT WIDTH_BUCKET(0, 10, NaN, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cb6d 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.592366 [ 610 ] {cb38da7c-2e0c-4369-ab13-d078730d4e48} TCPHandler: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, 10, nan, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cb6d 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.610660 [ 610 ] {78e02042-ba5d-4075-b1a3-a8456ae8d7f5} executeQuery: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(nan, 0, 10, 10). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET(NaN, 0, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cb6d 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.611916 [ 610 ] {78e02042-ba5d-4075-b1a3-a8456ae8d7f5} TCPHandler: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(nan, 0, 10, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cb6d 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.626645 [ 610 ] {b353a89d-97ff-4352-9f5c-bb95a369ae1f} executeQuery: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, nan, 10, 10). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET(0, NaN, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cb6d 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.627858 [ 610 ] {b353a89d-97ff-4352-9f5c-bb95a369ae1f} TCPHandler: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, nan, 10, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cb6d 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:37.716382 [ 16275 ] {fec5b875-ebb3-469b-99bd-6f82a836a3b9} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 billion, current rows: 100.00 billion: While executing Zeros. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49576) (comment: 03024_total_rows_approx_is_set_for_system_zeros_and_generate_random.sql) (in query: SELECT * FROM system.zeros LIMIT 1e12 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:37.718135 [ 16275 ] {fec5b875-ebb3-469b-99bd-6f82a836a3b9} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 billion, current rows: 100.00 billion: While executing Zeros. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:37.867599 [ 16278 ] {25d52178-eff0-4e78-aae7-a3b5abd8e99d} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49470) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(-170141183460469231731687303715884105728, -170141183460469231731687303715884105728);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001431d0a7 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000140bd2d9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:37.869212 [ 16278 ] {25d52178-eff0-4e78-aae7-a3b5abd8e99d} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001431d0a7 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000140bd2d9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:38.045708 [ 16275 ] {36990b92-673d-46ab-8e43-5dd214544fd1} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 billion, current rows: 100.00 billion: While executing Zeros. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49576) (comment: 03024_total_rows_approx_is_set_for_system_zeros_and_generate_random.sql) (in query: SELECT * FROM system.zeros_mt LIMIT 1e12 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:38.047636 [ 16275 ] {36990b92-673d-46ab-8e43-5dd214544fd1} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 billion, current rows: 100.00 billion: While executing Zeros. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:38.258051 [ 16275 ] {9d599b0e-38aa-45a6-b6e1-b96a09fcc554} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 billion, current rows: 100.00 billion: While executing GenerateRandom. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49576) (comment: 03024_total_rows_approx_is_set_for_system_zeros_and_generate_random.sql) (in query: SELECT * FROM generateRandom() LIMIT 1e12 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:38.280811 [ 16275 ] {9d599b0e-38aa-45a6-b6e1-b96a09fcc554} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 billion, current rows: 100.00 billion: While executing GenerateRandom. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:38.432073 [ 610 ] {cec4f5ba-6dbf-4cb1-861d-eca7b2e55e71} executeQuery: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, -inf, 10, 10). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: -- low and high cannot be Inf SELECT WIDTH_BUCKET(1, -Inf, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cd3f 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:38.433526 [ 610 ] {cec4f5ba-6dbf-4cb1-861d-eca7b2e55e71} TCPHandler: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, -inf, 10, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cd3f 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:38.452092 [ 610 ] {8223dac1-370f-4737-8a38-38c3e027536c} executeQuery: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, 0, inf, 10). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: -- low and high cannot be Inf SELECT WIDTH_BUCKET(1, 0, Inf, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cd3f 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:38.453579 [ 610 ] {8223dac1-370f-4737-8a38-38c3e027536c} TCPHandler: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, 0, inf, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x000000001cb2cd3f 5. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x000000001cb2c391 6. _ZNK2DB19FunctionWidthBucket20executeForResultTypeITkNS_9is_any_ofIDutjmEEDuEEN3COWINS_7IColumnEE13immutable_ptrIS4_EERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS8_9allocatorISA_EEEEm @ 0x000000001cb1f84d 7. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb1c1e4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:14:39.542215 [ 610 ] {983cdef6-3b9b-41bd-8454-736ce2719185} executeQuery: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int8.: In scope SELECT WIDTH_BUCKET(1, 2, 3, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET(1, 2, 3, -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1ce2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:39.543689 [ 610 ] {983cdef6-3b9b-41bd-8454-736ce2719185} TCPHandler: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int8.: In scope SELECT WIDTH_BUCKET(1, 2, 3, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1ce2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:39.562941 [ 610 ] {bb9e0426-eda3-44fb-bad8-7528cb6db965} executeQuery: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Float64.: In scope SELECT WIDTH_BUCKET(1, 2, 3, 1.3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET(1, 2, 3, 1.3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1ce2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:39.564336 [ 610 ] {bb9e0426-eda3-44fb-bad8-7528cb6db965} TCPHandler: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Float64.: In scope SELECT WIDTH_BUCKET(1, 2, 3, 1.3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1ce2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.382138 [ 610 ] {e5d4de69-bc42-4aad-8909-4f6a58361988} executeQuery: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET('a', 1, 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET('a', 1, 2, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1cb45 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.383543 [ 610 ] {e5d4de69-bc42-4aad-8909-4f6a58361988} TCPHandler: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET('a', 1, 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1cb45 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.402990 [ 610 ] {7c2eb475-57df-4d82-b0da-12a1eb3a8c00} executeQuery: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, toUInt128(42), 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET(1, toUInt128(42), 2, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1cb45 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.404309 [ 610 ] {7c2eb475-57df-4d82-b0da-12a1eb3a8c00} TCPHandler: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, toUInt128(42), 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1cb45 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.423160 [ 610 ] {23eb0d2b-ea74-4b93-be15-df94a0cc0c68} executeQuery: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, 2, toInt128(42), 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET(1, 2, toInt128(42), 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1cb45 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.424509 [ 610 ] {23eb0d2b-ea74-4b93-be15-df94a0cc0c68} TCPHandler: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, 2, toInt128(42), 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1cb45 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.444123 [ 610 ] {8cf37417-fc2a-4aae-8ab0-980bf4e6d0ce} executeQuery: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int256.: In scope SELECT WIDTH_BUCKET(1, 2, 3, toInt256(42)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49528) (comment: 02581_width_bucket.sql) (in query: SELECT WIDTH_BUCKET(1, 2, 3, toInt256(42));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1ce2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:40.445576 [ 610 ] {8cf37417-fc2a-4aae-8ab0-980bf4e6d0ce} TCPHandler: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int256.: In scope SELECT WIDTH_BUCKET(1, 2, 3, toInt256(42)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cb1ce2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:14:43.496367 [ 16275 ] {d118ab64-a342-4fb2-9073-de30fa1fd4ff} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 53.06 MiB (attempt to allocate chunk of 33554432 bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49594) (comment: 01062_pm_all_join_with_block_continuation.sql) (in query: SELECT count(1) FROM ( SELECT materialize(1) as k, n FROM numbers(10) nums JOIN (SELECT materialize(1) AS k, number n FROM numbers(1000000)) j USING k);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083835f3 9. ./build_docker/./src/Columns/ColumnVector.cpp:521: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037908e8d 10. ./src/Columns/IColumn.h:0: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x0000000034f0a42f 11. ./build_docker/./src/Interpreters/MergeJoin.cpp:836: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f12d7c 12. ./build_docker/./src/Interpreters/MergeJoin.cpp:733: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f081de 13. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:223: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003b82320b 14. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003b820c46 15. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::work() @ 0x000000003b81f21f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:43.500397 [ 16275 ] {d118ab64-a342-4fb2-9073-de30fa1fd4ff} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 53.06 MiB (attempt to allocate chunk of 33554432 bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083835f3 9. ./build_docker/./src/Columns/ColumnVector.cpp:521: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037908e8d 10. ./src/Columns/IColumn.h:0: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x0000000034f0a42f 11. ./build_docker/./src/Interpreters/MergeJoin.cpp:836: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f12d7c 12. ./build_docker/./src/Interpreters/MergeJoin.cpp:733: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f081de 13. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:223: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003b82320b 14. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003b820c46 15. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::work() @ 0x000000003b81f21f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:43.734792 [ 16275 ] {c9136d0e-050c-4dce-b2db-bca459cb3d28} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 50.02 MiB (attempt to allocate chunk of 32505856 bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49594) (comment: 01062_pm_all_join_with_block_continuation.sql) (in query: SELECT count(1) FROM ( SELECT materialize(1) as k, n FROM numbers(1000) nums JOIN (SELECT materialize(1) AS k, number n FROM numbers(10000)) j USING k);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083835f3 9. ./build_docker/./src/Columns/ColumnVector.cpp:521: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037908e8d 10. ./src/Columns/IColumn.h:0: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x0000000034f0a42f 11. ./build_docker/./src/Interpreters/MergeJoin.cpp:836: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f12d7c 12. ./build_docker/./src/Interpreters/MergeJoin.cpp:733: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f081de 13. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:223: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003b82320b 14. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003b820c46 15. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::work() @ 0x000000003b81f21f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:43.738756 [ 16275 ] {c9136d0e-050c-4dce-b2db-bca459cb3d28} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 50.02 MiB (attempt to allocate chunk of 32505856 bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083835f3 9. ./build_docker/./src/Columns/ColumnVector.cpp:521: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037908e8d 10. ./src/Columns/IColumn.h:0: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x0000000034f0a42f 11. ./build_docker/./src/Interpreters/MergeJoin.cpp:836: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f12d7c 12. ./build_docker/./src/Interpreters/MergeJoin.cpp:733: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000034f081de 13. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:223: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003b82320b 14. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003b820c46 15. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::work() @ 0x000000003b81f21f 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:43.900985 [ 31332 ] {34f44947-6994-4f73-b8f7-bbff90cbdf1c} executeQuery: Code: 42. DB::Exception: The signature of table function file shall be the following: - filename - filename, format - filename, format, structure - filename, format, structure, compression_method . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50502) (comment: 00758_array_reverse.sql) (in query: SELECT '[RE7', ( SELECT '\0' ) AS riwwq, ( SELECT reverse([( SELECT bitTestAll(NULL) ) , ( SELECT '\0' ) AS ddfweeuy]) ) AS xuvv, '', ( SELECT * FROM file() ) AS wqgdswyc, ( SELECT * FROM file() );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:61: DB::ITableFunctionFileLike::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002fe3efdf 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fe3d93c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:43.903183 [ 31332 ] {34f44947-6994-4f73-b8f7-bbff90cbdf1c} TCPHandler: Code: 42. DB::Exception: The signature of table function file shall be the following: - filename - filename, format - filename, format, structure - filename, format, structure, compression_method . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:61: DB::ITableFunctionFileLike::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002fe3efdf 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fe3d93c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:48.092293 [ 610 ] {76099124-f8a5-4dcb-8c64-5b8b8754071d} executeQuery: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT ceil(29375422, -54212). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50544) (comment: 00161_rounding_functions.sql) (in query: SELECT ceil(29375422, -54212) --{serverError ARGUMENT_OUT_OF_BOUND} ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. COW::immutable_ptr DB::Dispatcher::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000b09284f 5. bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000b02121c 6. DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b019aeb 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:48.094016 [ 610 ] {76099124-f8a5-4dcb-8c64-5b8b8754071d} TCPHandler: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT ceil(29375422, -54212). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. COW::immutable_ptr DB::Dispatcher::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000b09284f 5. bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000b02121c 6. DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b019aeb 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:14:48.293579 [ 16279 ] {f52652be-2ee7-4960-a614-ea597a954e82} executeQuery: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50594) (comment: 01010_pm_join_all_join_bug.sql) (in query: SELECT count() FROM ( SELECT [1], count(1) ) AS t1 ALL RIGHT JOIN ( SELECT number AS s FROM numbers(2) ) AS t2 USING (s);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:48.295474 [ 16279 ] {f52652be-2ee7-4960-a614-ea597a954e82} TCPHandler: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:55.779732 [ 31332 ] {6674bfe5-4de7-49f7-b4f7-4a58e14415ec} executeQuery: Code: 131. DB::Exception: The string size is too big for function editDistance, should be at most 65536: while executing 'FUNCTION editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT editDistance(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteEditDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b4633ba 5. DB::FunctionsStringSimilarity>, DB::NameEditDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4607ae 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:55.782005 [ 31332 ] {6674bfe5-4de7-49f7-b4f7-4a58e14415ec} TCPHandler: Code: 131. DB::Exception: The string size is too big for function editDistance, should be at most 65536: while executing 'FUNCTION editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteEditDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b4633ba 5. DB::FunctionsStringSimilarity>, DB::NameEditDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4607ae 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:56.584980 [ 31332 ] {a4380c0a-752c-482c-af62-8c9e9cd0483e} executeQuery: Code: 131. DB::Exception: The string size is too big for function damerauLevenshteinDistance, should be at most 65536: while executing 'FUNCTION damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT damerauLevenshteinDistance(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteDamerauLevenshteinDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b46ddb6 5. DB::FunctionsStringSimilarity, DB::NameDamerauLevenshteinDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b46b2ae 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:56.587039 [ 31332 ] {a4380c0a-752c-482c-af62-8c9e9cd0483e} TCPHandler: Code: 131. DB::Exception: The string size is too big for function damerauLevenshteinDistance, should be at most 65536: while executing 'FUNCTION damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteDamerauLevenshteinDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b46ddb6 5. DB::FunctionsStringSimilarity, DB::NameDamerauLevenshteinDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b46b2ae 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:57.326864 [ 31332 ] {46d40dd9-97df-4cc5-8dea-fc9f5b33aa7d} executeQuery: Code: 131. DB::Exception: The string size is too big for function jaroSimilarity, should be at most 65536: while executing 'FUNCTION jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT jaroSimilarity(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteJaroSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b47c741 5. DB::FunctionsStringSimilarity, DB::NameJaroSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47a34e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:57.328879 [ 31332 ] {46d40dd9-97df-4cc5-8dea-fc9f5b33aa7d} TCPHandler: Code: 131. DB::Exception: The string size is too big for function jaroSimilarity, should be at most 65536: while executing 'FUNCTION jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteJaroSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b47c741 5. DB::FunctionsStringSimilarity, DB::NameJaroSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47a34e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:58.051309 [ 31332 ] {be903b22-086f-4192-8efc-c525aa6b609f} executeQuery: Code: 131. DB::Exception: The string size is too big for function jaroWinklerSimilarity, should be at most 65536: while executing 'FUNCTION jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT jaroWinklerSimilarity(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteJaroWinklerSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b4801b6 5. DB::FunctionsStringSimilarity, DB::NameJaroWinklerSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47e38e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:58.053450 [ 31332 ] {be903b22-086f-4192-8efc-c525aa6b609f} TCPHandler: Code: 131. DB::Exception: The string size is too big for function jaroWinklerSimilarity, should be at most 65536: while executing 'FUNCTION jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::ByteJaroWinklerSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b4801b6 5. DB::FunctionsStringSimilarity, DB::NameJaroWinklerSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47e38e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.733253 [ 31332 ] {e1716bac-3d60-4ce6-bbde-ecd9c872e54b} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Â': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Â'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Â'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xC2\x01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.735286 [ 31332 ] {e1716bac-3d60-4ce6-bbde-ecd9c872e54b} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Â': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Â'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Â'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.780562 [ 31332 ] {e5e95140-a1d1-4854-9327-ad408b4f3f43} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Á': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Á'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Á'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xC1\x81'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.782854 [ 31332 ] {e5e95140-a1d1-4854-9327-ad408b4f3f43} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Á': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Á'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Á'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.822256 [ 31332 ] {164f268d-a89e-4603-ad98-7474398e2d6b} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'ð€€A': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('ð€€A'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('ð€€A'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xF0\x80\x80\x41'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.824188 [ 31332 ] {164f268d-a89e-4603-ad98-7474398e2d6b} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'ð€€A': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('ð€€A'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('ð€€A'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.863180 [ 31332 ] {43163588-2e74-4350-aa51-16b32492e874} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'À€': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('À€'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('À€'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xC0\x80'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.866220 [ 31332 ] {43163588-2e74-4350-aa51-16b32492e874} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'À€': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('À€'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('À€'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.904403 [ 31332 ] {1dbf360f-40f2-44a8-9eaf-375e320dd344} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ø ': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ø\0 '_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ø\0 '_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xD8\x00 '));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.906328 [ 31332 ] {1dbf360f-40f2-44a8-9eaf-375e320dd344} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ø ': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ø\0 '_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ø\0 '_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.949382 [ 31332 ] {0322953d-ebd6-4917-8829-83400551ede8} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ü': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ü\0'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ü\0'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54834) (comment: 02884_string_distance_function.sql) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xDC\x00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:14:59.952781 [ 31332 ] {0322953d-ebd6-4917-8829-83400551ede8} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ü': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ü\0'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ü\0'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&&) @ 0x000000000b452b8a 4. DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000b45167a 5. DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b476772 6. DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b474953 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:02.127243 [ 610 ] {17cea77c-0f43-49fa-b46c-fc3be4001e24} executeQuery: Code: 60. DB::Exception: Temporary table table_to_drop doesn't exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46530) (comment: 01072_drop_temporary_table_with_same_name.sql) (in query: DROP TEMPORARY TABLE table_to_drop;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:137: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492dad8 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:02.128778 [ 610 ] {17cea77c-0f43-49fa-b46c-fc3be4001e24} TCPHandler: Code: 60. DB::Exception: Temporary table table_to_drop doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:137: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492dad8 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:02.586376 [ 610 ] {daf9680d-be61-4c21-9e9b-a42c039e1f24} executeQuery: Code: 60. DB::Exception: Table test_szs9b3t7.table_to_drop does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46530) (comment: 01072_drop_temporary_table_with_same_name.sql) (in query: DROP TABLE table_to_drop;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:02.587955 [ 610 ] {daf9680d-be61-4c21-9e9b-a42c039e1f24} TCPHandler: Code: 60. DB::Exception: Table test_szs9b3t7.table_to_drop does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:02.696842 [ 610 ] {64b492fc-88c9-420f-a038-e2f8e9a72954} executeQuery: Code: 60. DB::Exception: Table test_szs9b3t7.table_to_drop does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46530) (comment: 01072_drop_temporary_table_with_same_name.sql) (in query: DROP TABLE table_to_drop;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:02.698211 [ 610 ] {64b492fc-88c9-420f-a038-e2f8e9a72954} TCPHandler: Code: 60. DB::Exception: Table test_szs9b3t7.table_to_drop does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.244862 [ 16278 ] {66b28a9e-4694-460d-a2af-1278619de4ba} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t1.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.246692 [ 16278 ] {66b28a9e-4694-460d-a2af-1278619de4ba} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.284862 [ 16278 ] {a8e92be5-86c9-4f63-8099-7f167c4193f4} executeQuery: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) AS t1 INNER JOIN numbers(10) AS t2 ON t1.number = t2.number GROUP BY t1.number. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.number FROM numbers(10) as t1 JOIN numbers(10) as t2 ON t1.number = t2.number GROUP BY t1.number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.286825 [ 16278 ] {a8e92be5-86c9-4f63-8099-7f167c4193f4} TCPHandler: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) AS t1 INNER JOIN numbers(10) AS t2 ON t1.number = t2.number GROUP BY t1.number. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.333309 [ 16278 ] {c5b95517-1aca-4e42-827a-8973c17959f8} executeQuery: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.a FROM (SELECT x as a FROM t1) as t1 JOIN (SELECT x as a FROM t1) as t2 ON t1.a = t2.a GROUP BY t1.a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.335897 [ 16278 ] {c5b95517-1aca-4e42-827a-8973c17959f8} TCPHandler: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.436562 [ 16278 ] {df441027-6861-4814-a8ac-4da1500cda2b} executeQuery: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.a FROM (SELECT x as a FROM t1 UNION ALL SELECT x as a FROM t1) as t1 JOIN (SELECT x as a FROM t1 UNION ALL SELECT x as a FROM t1) as t2 ON t1.a = t2.a GROUP BY t1.a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.438766 [ 16278 ] {df441027-6861-4814-a8ac-4da1500cda2b} TCPHandler: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.471713 [ 16278 ] {6b26dc63-a84f-458d-96fc-8df451614d31} executeQuery: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) INNER JOIN numbers(10) AS t2 ON number = t2.number GROUP BY number SETTINGS joined_subquery_requires_alias = 0. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.number FROM numbers(10) JOIN numbers(10) as t2 ON number = t2.number GROUP BY number SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.474010 [ 16278 ] {6b26dc63-a84f-458d-96fc-8df451614d31} TCPHandler: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) INNER JOIN numbers(10) AS t2 ON number = t2.number GROUP BY number SETTINGS joined_subquery_requires_alias = 0. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.504840 [ 16278 ] {04d65027-3785-43fd-8792-389f08ac440f} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.x FROM t1 as t0 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t1.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.506574 [ 16278 ] {04d65027-3785-43fd-8792-389f08ac440f} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.536606 [ 16278 ] {08dbfc31-0cf1-4a7e-903d-b1a5fc181b24} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t0.x = t2.x GROUP BY t0.x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.x FROM t1 as t0 JOIN t1 as t2 ON t0.x = t2.x GROUP BY t0.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.538615 [ 16278 ] {08dbfc31-0cf1-4a7e-903d-b1a5fc181b24} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t0.x = t2.x GROUP BY t0.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.569479 [ 16278 ] {30fe56d8-4072-411c-b09b-4170311c66df} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t2.x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.571573 [ 16278 ] {30fe56d8-4072-411c-b09b-4170311c66df} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.602531 [ 16278 ] {8ab0fcfe-bd7b-4911-87f6-dd8f07022fa4} executeQuery: Code: 215. DB::Exception: Column test_q41p5d2z.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT t1.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT t1.x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t2.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.604244 [ 16278 ] {8ab0fcfe-bd7b-4911-87f6-dd8f07022fa4} TCPHandler: Code: 215. DB::Exception: Column test_q41p5d2z.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT t1.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.637796 [ 16278 ] {9d27794c-9ab1-493e-b179-32eacbce3710} executeQuery: Code: 215. DB::Exception: Column test_q41p5d2z.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t2.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.639840 [ 16278 ] {9d27794c-9ab1-493e-b179-32eacbce3710} TCPHandler: Code: 215. DB::Exception: Column test_q41p5d2z.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.667197 [ 16278 ] {8861de00-c41f-4e14-998c-249964fb9918} executeQuery: Code: 215. DB::Exception: Column test_q41p5d2z.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 USING (x) GROUP BY t2.x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42964) (comment: 03130_analyzer_self_join_group_by.sql) (in query: SELECT x FROM t1 JOIN t1 as t2 USING (x) GROUP BY t2.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:15.668994 [ 16278 ] {8861de00-c41f-4e14-998c-249964fb9918} TCPHandler: Code: 215. DB::Exception: Column test_q41p5d2z.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 USING (x) GROUP BY t2.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:18.217084 [ 1534 ] {f50b46da-db3a-4613-a3a9-77dff353956c} executeQuery: Code: 80. DB::Exception: The maximum rows per postings list must be no less than 8192. (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54790) (comment: 02346_fulltext_index_search.sql) (in query: CREATE TABLE tab (`k` UInt64, `s` String, INDEX af s TYPE full_text(3, 123) GRANULARITY 1) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 31905, min_bytes_for_wide_part = 483040799, ratio_of_defaults_for_sparse_serialization = 0.6249917149543762, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 353829735, compact_parts_max_granules_to_buffer = 229, compact_parts_merge_max_bytes_to_prefetch_part = 20403100, merge_max_block_size = 19445, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 86318, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8662627974, index_granularity_bytes = 20595121, concurrent_part_removal_threshold = 78, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 46090, primary_key_compress_block_size = 14496 AS SELECT number, format('{},{},{},{}', hex(12345678), hex(87654321), hex((number / 17) + 5), hex(13579012)) AS s FROM numbers(1024)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:0: DB::fullTextIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039a9046f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:18.219135 [ 1534 ] {f50b46da-db3a-4613-a3a9-77dff353956c} TCPHandler: Code: 80. DB::Exception: The maximum rows per postings list must be no less than 8192. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:0: DB::fullTextIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039a9046f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.609884 [ 33053 ] {e1fce172-e5c0-4dd9-9586-70b76f325d74} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43154) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t24227 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.609914 [ 1534 ] {cb6bac66-38a3-43ae-8068-2aee2ce1bcd0} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43184) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t6577 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.613140 [ 33053 ] {e1fce172-e5c0-4dd9-9586-70b76f325d74} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.613478 [ 1534 ] {cb6bac66-38a3-43ae-8068-2aee2ce1bcd0} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.883212 [ 31332 ] {f1d4d605-2405-4d47-b985-8b353a2745d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: -- incorrect number of arguments SELECT base64URLEncode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.884686 [ 31332 ] {f1d4d605-2405-4d47-b985-8b353a2745d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.903369 [ 31332 ] {89fe2af4-f75e-45dd-b9a2-5051703cfc8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.904910 [ 31332 ] {89fe2af4-f75e-45dd-b9a2-5051703cfc8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.923175 [ 31332 ] {1508f779-5eee-40e1-82dc-77574f43fa7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: SELECT tryBase64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.924604 [ 31332 ] {1508f779-5eee-40e1-82dc-77574f43fa7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.943277 [ 31332 ] {75ae83d7-2c40-4638-87e2-0f9759493c87} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLEncode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.944804 [ 31332 ] {75ae83d7-2c40-4638-87e2-0f9759493c87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.966492 [ 31332 ] {6e2c505d-f0fc-4114-bd37-4b15025cf55e} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.968079 [ 31332 ] {6e2c505d-f0fc-4114-bd37-4b15025cf55e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.988433 [ 31332 ] {fdee85ee-3945-47ac-9ab4-3a4834e5bd5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: SELECT tryBase64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:21.990122 [ 31332 ] {fdee85ee-3945-47ac-9ab4-3a4834e5bd5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:22.670184 [ 610 ] {01e20f18-dfd1-4f7d-80d5-06deced43163} executeQuery: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38812) (comment: 02949_parallel_replicas_in_subquery.sql) (in query: SELECT * FROM merge_tree_in_subqueries WHERE id IN (SELECT * FROM system.numbers LIMIT 0) SETTINGS enable_parallel_replicas=2, parallel_replicas_allow_in_with_subquery=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0f88d 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:22.672519 [ 610 ] {01e20f18-dfd1-4f7d-80d5-06deced43163} TCPHandler: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0f88d 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:22.975289 [ 33053 ] {f53e9047-cb47-4b54-bfb2-f007022db603} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38876) (comment: 01444_create_table_drop_database_race.sh) (in query: DROP DATABASE IF EXISTS test_783), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399e61a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034935037 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034926dad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923f21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:22.977660 [ 33053 ] {f53e9047-cb47-4b54-bfb2-f007022db603} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399e61a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034935037 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034926dad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923f21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:23.072824 [ 610 ] {2e65ebf2-bd43-4a62-945d-c34308454904} executeQuery: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38812) (comment: 02949_parallel_replicas_in_subquery.sql) (in query: SELECT * FROM merge_tree_in_subqueries WHERE id IN (SELECT * FROM system.numbers LIMIT 2, 3) ORDER BY id SETTINGS enable_parallel_replicas=2, parallel_replicas_allow_in_with_subquery=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0f88d 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:23.075110 [ 610 ] {2e65ebf2-bd43-4a62-945d-c34308454904} TCPHandler: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0f88d 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:23.262212 [ 31332 ] {784026f7-2215-4ec4-a6fb-bb44bfcd6051} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: -- test with invalid inputs SELECT base64URLDecode('https://clickhouse.com');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000bba6327 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000bba5c7f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bba4a3e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:15:23.273278 [ 31332 ] {784026f7-2215-4ec4-a6fb-bb44bfcd6051} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000bba6327 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000bba5c7f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bba4a3e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:15:23.329073 [ 31332 ] {320063ea-d9ca-40ec-8aea-4589053ef1aa} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode('12?');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000bba6327 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000bba5c7f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bba4a3e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:15:23.330655 [ 31332 ] {320063ea-d9ca-40ec-8aea-4589053ef1aa} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000bba6327 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000bba5c7f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bba4a3e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:15:23.385057 [ 31332 ] {43cd1e13-ac27-475a-902f-5c393be91b71} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38822) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode('aHR0cHM6Ly9jbGlja');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000bba6327 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000bba5c7f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bba4a3e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:15:23.386562 [ 31332 ] {43cd1e13-ac27-475a-902f-5c393be91b71} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000bb9bc0d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000bba6327 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000bba5c7f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bba4a3e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:15:23.530303 [ 610 ] {4ad48bf0-7395-4964-860a-1a2ede1f8af0} executeQuery: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38812) (comment: 02949_parallel_replicas_in_subquery.sql) (in query: SELECT * FROM merge_tree_in_subqueries WHERE id IN (SELECT 1) ORDER BY id SETTINGS enable_parallel_replicas=2, parallel_replicas_allow_in_with_subquery=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0f88d 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:23.532102 [ 610 ] {4ad48bf0-7395-4964-860a-1a2ede1f8af0} TCPHandler: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0f88d 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:24.915267 [ 610 ] {3c259749-7d88-4089-b296-421bfcc273ae} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39022) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t8321 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:24.923642 [ 610 ] {3c259749-7d88-4089-b296-421bfcc273ae} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:25.058752 [ 16279 ] {8dc64c87-e417-42e2-a6b2-86e2dfeca275} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39042) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t25285 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:25.061323 [ 16279 ] {8dc64c87-e417-42e2-a6b2-86e2dfeca275} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:25.578177 [ 33053 ] {3912fe11-9645-49a1-aa29-db82e03e44e5} executeQuery: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_indes` to drop, may be you meant: ['test_index']. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39048) (comment: 02225_hints_for_indeices.sh) (in query: ALTER TABLE t DROP INDEX test_indes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Storages/AlterCommands.cpp:692: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038086eeb 5. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:25.581354 [ 33053 ] {3912fe11-9645-49a1-aa29-db82e03e44e5} TCPHandler: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_indes` to drop, may be you meant: ['test_index']. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Storages/AlterCommands.cpp:692: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038086eeb 5. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:25.784373 [ 610 ] {8df38a84-f34e-4c47-99a8-d4507246811b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39080) (comment: 01444_create_table_drop_database_race.sh) (in query: DROP DATABASE IF EXISTS test_783), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399e61a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034935037 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034926dad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923f21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:25.806452 [ 610 ] {8df38a84-f34e-4c47-99a8-d4507246811b} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399e61a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034935037 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034926dad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923f21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:26.745961 [ 16279 ] {3367cd95-a852-4778-bca4-d4a21b214244} executeQuery: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_indes` to insert after, may be you meant: ['test_index']. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39090) (comment: 02225_hints_for_indeices.sh) (in query: ALTER TABLE t ADD INDEX test_index1 n TYPE minmax GRANULARITY 4 AFTER test_indes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Storages/AlterCommands.cpp:665: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038086c32 5. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:26.748656 [ 16279 ] {3367cd95-a852-4778-bca4-d4a21b214244} TCPHandler: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_indes` to insert after, may be you meant: ['test_index']. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Storages/AlterCommands.cpp:665: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038086c32 5. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:27.726018 [ 16279 ] {e12cde78-abff-442b-83e1-419cf36de9a0} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39186) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t8310 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:27.730008 [ 16279 ] {e12cde78-abff-442b-83e1-419cf36de9a0} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:27.752577 [ 612 ] {4e8006c4-ca00-4ee7-ba06-1a8c05c296ad} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39190) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t25608 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:27.755244 [ 612 ] {4e8006c4-ca00-4ee7-ba06-1a8c05c296ad} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:28.507187 [ 16279 ] {56b87a74-20c6-486e-89b9-2c4e2673b887} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39230) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t26056 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:28.510400 [ 16279 ] {56b87a74-20c6-486e-89b9-2c4e2673b887} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:28.539181 [ 1534 ] {8fd730aa-ade8-443d-8592-55c24574f93e} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39244) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t9251 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:28.542170 [ 1534 ] {8fd730aa-ade8-443d-8592-55c24574f93e} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:30.097964 [ 16279 ] {35e55b46-a009-42c4-a748-1deee9ac1fd6} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39298) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t29759 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:30.101017 [ 16279 ] {35e55b46-a009-42c4-a748-1deee9ac1fd6} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:30.128360 [ 16278 ] {0f0b47a2-b048-49f0-a873-5c7609f23cc7} executeQuery: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39304) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_783.t10724 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 41737, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 377380213, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 22260739, merge_max_block_size = 6012, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4530856414, index_granularity_bytes = 24956897, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 99238, primary_key_compress_block_size = 35256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:30.131088 [ 16278 ] {0f0b47a2-b048-49f0-a873-5c7609f23cc7} TCPHandler: Code: 81. DB::Exception: Database test_783 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1471: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c150d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:34.533444 [ 16279 ] {015addbe-8f9d-4420-80dc-c01ab94e353f} executeQuery: Code: 507. DB::Exception: Sharding key key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34812) (comment: 01211_optimize_skip_unused_shards_type_mismatch.sql) (in query: select * from dist_02000 where key = 0xdeadbeafdeadbeaf settings force_optimize_skip_unused_shards=2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:34.534983 [ 16279 ] {015addbe-8f9d-4420-80dc-c01ab94e353f} TCPHandler: Code: 507. DB::Exception: Sharding key key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264e48 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:36.877946 [ 16275 ] {2e5924ed-9ceb-4b03-817f-f9ba3a4526aa} executeQuery: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34906) (comment: 02985_minmax_index_aggregate_function.sql) (in query: CREATE TABLE t_index_agg_func (`id` UInt64, `v` AggregateFunction(avg, UInt64), INDEX idx_v v TYPE minmax GRANULARITY 1) ENGINE = AggregatingMergeTree ORDER BY id SETTINGS index_granularity = 4, min_bytes_for_wide_part = 734521617, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 529554085, compact_parts_max_bytes_to_buffer = 507348715, compact_parts_max_granules_to_buffer = 68, compact_parts_merge_max_bytes_to_prefetch_part = 30844957, merge_max_block_size = 23611, old_parts_lifetime = 334., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 824574, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 14042327, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 62637, primary_key_compress_block_size = 17184), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039ad5645 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:36.880168 [ 16275 ] {2e5924ed-9ceb-4b03-817f-f9ba3a4526aa} TCPHandler: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039ad5645 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:37.444572 [ 16275 ] {a597d9c7-719e-45af-be52-5ee993253cb1} executeQuery: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34906) (comment: 02985_minmax_index_aggregate_function.sql) (in query: ALTER TABLE t_index_agg_func ADD INDEX idx_v v TYPE minmax GRANULARITY 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039ad5645 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039752b30 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:37.446612 [ 16275 ] {a597d9c7-719e-45af-be52-5ee993253cb1} TCPHandler: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039ad5645 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039752b30 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:41.735784 [ 35005 ] {4b67ce80-daff-4847-9da7-da71acacdc70} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35086) (comment: 02155_dictionary_comment.sql) (in query: ALTER TABLE 02155_test_dictionary COMMENT COLUMN value 'value_column';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000030c5860d 4. ./build_docker/./src/Storages/StorageDictionary.cpp:287: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000038249743 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:41.737354 [ 35005 ] {4b67ce80-daff-4847-9da7-da71acacdc70} TCPHandler: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000030c5860d 4. ./build_docker/./src/Storages/StorageDictionary.cpp:287: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000038249743 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:42.515904 [ 35005 ] {ef91af1f-68fb-4142-8f9a-06f26c8570de} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35086) (comment: 02155_dictionary_comment.sql) (in query: ALTER TABLE 02155_test_dictionary_view COMMENT COLUMN value 'value_column';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000030c5860d 4. ./build_docker/./src/Storages/StorageDictionary.cpp:287: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000038249743 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:42.517590 [ 35005 ] {ef91af1f-68fb-4142-8f9a-06f26c8570de} TCPHandler: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000030c5860d 4. ./build_docker/./src/Storages/StorageDictionary.cpp:287: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000038249743 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:45.555235 [ 1391 ] {92e68481-8b3a-4f2d-bad1-4e2c6be132de} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_yq0q4n46.async_inserts FORMAT CSV' with query id 2b4b0ac3-076c-4007-9912-03758dd2c013. DB::Exception: Cannot parse input: expected ',' before: 'qqqqqqqqqqq': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) 2025.06.18 11:15:45.911965 [ 16279 ] {2b4b0ac3-076c-4007-9912-03758dd2c013} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: 'qqqqqqqqqqq': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41990) (comment: 02015_async_inserts_2.sh) (in query: INSERT INTO async_inserts FORMAT CSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:15:45.916229 [ 16279 ] {2b4b0ac3-076c-4007-9912-03758dd2c013} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: 'qqqqqqqqqqq': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aecb74c 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aecb0b3 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364ff23 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365b4cf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:02.133176 [ 16279 ] {f05325f4-407e-4c0a-bdc3-7a7d93ae5856} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50736) (comment: 03036_reading_s3_archives.sql) (in query: select id, data, _size, _file, _path from s3(s3_conn, filename='03036_archive2.zip :: nonexistent.csv');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:196: DB::ReadBufferIterator::next() @ 0x0000000030a07c69 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad896da 6. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309eeb07 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a7cd4e 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e4fdd 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff27f99 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff2787d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef2ae6 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 14. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:16:02.139462 [ 16279 ] {f05325f4-407e-4c0a-bdc3-7a7d93ae5856} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:196: DB::ReadBufferIterator::next() @ 0x0000000030a07c69 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad896da 6. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309eeb07 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a7cd4e 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e4fdd 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff27f99 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff2787d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef2ae6 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 14. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:16:02.427932 [ 16279 ] {38ab76b9-8794-4f46-a649-07449a3e3d4d} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50736) (comment: 03036_reading_s3_archives.sql) (in query: select id, data, _size, _file, _path from s3(s3_conn, filename='03036_archive2.zip :: nonexistent{2..3}.csv');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:196: DB::ReadBufferIterator::next() @ 0x0000000030a07c69 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad896da 6. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309eeb07 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a7cd4e 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e4fdd 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff27f99 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff2787d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef2ae6 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 14. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:16:02.429861 [ 16279 ] {38ab76b9-8794-4f46-a649-07449a3e3d4d} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:196: DB::ReadBufferIterator::next() @ 0x0000000030a07c69 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad896da 6. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309eeb07 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a7cd4e 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e4fdd 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff27f99 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff2787d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef2ae6 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 14. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:16:04.714581 [ 36047 ] {51d56f16-fdfd-4044-b628-391f73b824ea} executeQuery: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49312) (comment: 03203_variant_convert_field_to_type_bug.sql) (in query: SELECT * FROM numbers([tuple(1, 2), NULL], 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:108: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000002fdf3723 5. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdf19fb 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:04.720943 [ 36047 ] {51d56f16-fdfd-4044-b628-391f73b824ea} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:108: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000002fdf3723 5. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdf19fb 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:06.880366 [ 16279 ] {7df2df0f-3753-42e8-8795-b2eb1e3b2953} executeQuery: Code: 56. DB::Exception: Unknown table engine s3. (UNKNOWN_STORAGE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50736) (comment: 03036_reading_s3_archives.sql) (in query: CREATE table table_noexist Engine s3(s3_conn, filename='03036_archive2.zip :: nonexistent.csv');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFactory.cpp:261: DB::StorageFactory::getStorageFeatures(String const&) const @ 0x00000000382f6c6f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:874: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a568e 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:06.881983 [ 16279 ] {7df2df0f-3753-42e8-8795-b2eb1e3b2953} TCPHandler: Code: 56. DB::Exception: Unknown table engine s3. (UNKNOWN_STORAGE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFactory.cpp:261: DB::StorageFactory::getStorageFeatures(String const&) const @ 0x00000000382f6c6f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:874: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a568e 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:17.734890 [ 36000 ] {ac3443f2-658b-4c52-964b-bd320c2bfb7e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:47606). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47606) (comment: 00991_system_parts_race_condition_long.sh) (in query: INSERT INTO alter_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003abe937b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaede0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:17.734935 [ 35647 ] {7dfdcff8-46b6-4973-a708-f02b9c53934d} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49364). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49364) (comment: 00991_system_parts_race_condition_long.sh) (in query: INSERT INTO alter_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003abe937b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaede0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:17.972307 [ 35636 ] {41909ec6-fa38-49c4-8240-7950a7332e84} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:49212, local: [::1]:9000). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49212) (comment: 00991_system_parts_race_condition_long.sh) (in query: INSERT INTO alter_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003abe10f9 8. ./build_docker/./src/Server/TCPHandler.cpp:0: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ac089ae 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:99: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae75a58 10. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abaecce 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:18.069490 [ 31332 ] {1253ea1d-a9a1-4e84-94bf-6584debdb3bf} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:47724). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47724) (comment: 00991_system_parts_race_condition_long.sh) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abe3b95 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1770 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:18.221446 [ 35636 ] {41909ec6-fa38-49c4-8240-7950a7332e84} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49212). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:18.221270 [ 35647 ] {7dfdcff8-46b6-4973-a708-f02b9c53934d} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49364). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:18.221179 [ 36000 ] {ac3443f2-658b-4c52-964b-bd320c2bfb7e} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:47606). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:18.221134 [ 31332 ] {1253ea1d-a9a1-4e84-94bf-6584debdb3bf} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:47724). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:18.229563 [ 35636 ] {41909ec6-fa38-49c4-8240-7950a7332e84} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:49212, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003abe10f9 8. ./build_docker/./src/Server/TCPHandler.cpp:0: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ac089ae 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:99: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae75a58 10. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abaecce 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:18.229784 [ 35647 ] {7dfdcff8-46b6-4973-a708-f02b9c53934d} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49364). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003abe937b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaede0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:18.230401 [ 35636 ] {41909ec6-fa38-49c4-8240-7950a7332e84} TCPHandler: Client has gone away. 2025.06.18 11:16:18.234018 [ 31332 ] {1253ea1d-a9a1-4e84-94bf-6584debdb3bf} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:47724). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abe3b95 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1770 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:18.234630 [ 31332 ] {1253ea1d-a9a1-4e84-94bf-6584debdb3bf} TCPHandler: Client has gone away. 2025.06.18 11:16:18.236361 [ 36000 ] {ac3443f2-658b-4c52-964b-bd320c2bfb7e} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:47606). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003abe937b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaede0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:18.236781 [ 35647 ] {7dfdcff8-46b6-4973-a708-f02b9c53934d} TCPHandler: Client has gone away. 2025.06.18 11:16:18.237256 [ 36000 ] {ac3443f2-658b-4c52-964b-bd320c2bfb7e} TCPHandler: Client has gone away. 2025.06.18 11:16:22.321320 [ 36047 ] {a44db95c-d1bb-4979-af3b-c8bf19e4244b} executeQuery: Code: 6. DB::Exception: Illegal character '\x0d' in partition id starting with 'test_'. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:22.334175 [ 36047 ] {a44db95c-d1bb-4979-af3b-c8bf19e4244b} TCPHandler: Code: 6. DB::Exception: Illegal character '\x0d' in partition id starting with 'test_'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:22.402597 [ 36047 ] {7ace3578-bc69-487d-93af-a4a125cd8aec} executeQuery: Code: 6. DB::Exception: Illegal character '\x00' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:22.414448 [ 36047 ] {7ace3578-bc69-487d-93af-a4a125cd8aec} TCPHandler: Code: 6. DB::Exception: Illegal character '\x00' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:23.333848 [ 36047 ] {fb4d69a3-d10a-4afc-9241-501ad5d00686} executeQuery: Code: 6. DB::Exception: Incorrect non-UTF8 sequence in key. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:150: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14b90 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:23.342820 [ 36047 ] {fb4d69a3-d10a-4afc-9241-501ad5d00686} TCPHandler: Code: 6. DB::Exception: Incorrect non-UTF8 sequence in key. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:150: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14b90 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:23.400519 [ 36047 ] {0d707557-a01c-4b65-9be7-0b3bea30d2cf} executeQuery: Code: 6. DB::Exception: Illegal character '\x7d' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:23.409167 [ 36047 ] {0d707557-a01c-4b65-9be7-0b3bea30d2cf} TCPHandler: Code: 6. DB::Exception: Illegal character '\x7d' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:23.461415 [ 36047 ] {18603e80-d245-4284-82b3-818f59a1a8d6} executeQuery: Code: 6. DB::Exception: Illegal character '\x2a' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:23.469993 [ 36047 ] {18603e80-d245-4284-82b3-818f59a1a8d6} TCPHandler: Code: 6. DB::Exception: Illegal character '\x2a' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14846 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:24.349004 [ 36047 ] {edc23f4c-8010-4823-82d6-cfa0440cf6e0} executeQuery: Code: 36. DB::Exception: Incorrect key length (not empty, max 1023 characters), got: 0. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/{_partition_id}', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:147: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14a40 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:24.358245 [ 36047 ] {edc23f4c-8010-4823-82d6-cfa0440cf6e0} TCPHandler: Code: 36. DB::Exception: Incorrect key length (not empty, max 1023 characters), got: 0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:147: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000030a14a40 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:124: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13df0 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:25.221226 [ 36047 ] {106a51fb-df20-443d-990d-b2989947fbe4} executeQuery: Code: 36. DB::Exception: Bucket name length is out of bounds in virtual hosted style S3 URI: ''. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/{_partition_id}/key.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/IO/S3/URI.cpp:165: DB::S3::URI::validateBucket(String const&, Poco::URI const&) @ 0x0000000030ad884d 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::validateNamespace(String const&) const @ 0x0000000030ab1b8e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000030a14453 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13ca1 8. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 9. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:25.229536 [ 36047 ] {106a51fb-df20-443d-990d-b2989947fbe4} TCPHandler: Code: 36. DB::Exception: Bucket name length is out of bounds in virtual hosted style S3 URI: ''. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/IO/S3/URI.cpp:165: DB::S3::URI::validateBucket(String const&, Poco::URI const&) @ 0x0000000030ad884d 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::validateNamespace(String const&) const @ 0x0000000030ab1b8e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000030a14453 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13ca1 8. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 9. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:26.041057 [ 36047 ] {9b7b8e3d-bcb0-40cc-a6ae-eb22bcd4bc45} executeQuery: Code: 6. DB::Exception: Illegal character '\x2f' in partition id starting with 'aa'. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47866) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/{_partition_id}/key.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:163: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000030a144e5 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13ca1 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:26.049872 [ 36047 ] {9b7b8e3d-bcb0-40cc-a6ae-eb22bcd4bc45} TCPHandler: Code: 6. DB::Exception: Illegal character '\x2f' in partition id starting with 'aa'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000381ed8ad 4. ./build_docker/./src/Storages/PartitionedSink.cpp:136: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000381eb423 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:163: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000030a144e5 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000030a13ca1 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000381e53fd 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000381e8bc2 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 10. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:28.001140 [ 35661 ] {479e02e1-fbf7-420a-8d26-31c395081b46} executeQuery: Code: 51. DB::Exception: Empty list of columns in projection. In scope SELECT COLUMNS('x') FROM numbers(10) WHERE number > 5. (EMPTY_LIST_OF_COLUMNS_QUERIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58634) (comment: 00969_columns_clause.sql) (in query: SELECT COLUMNS('x') FROM numbers(10) WHERE number > 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5433: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033431750 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:28.002840 [ 35661 ] {479e02e1-fbf7-420a-8d26-31c395081b46} TCPHandler: Code: 51. DB::Exception: Empty list of columns in projection. In scope SELECT COLUMNS('x') FROM numbers(10) WHERE number > 5. (EMPTY_LIST_OF_COLUMNS_QUERIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5433: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033431750 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:28.260821 [ 35661 ] {4289fae3-2575-4431-9578-43f626d79f12} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT COLUMNS('n') + COLUMNS('u') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58634) (comment: 00969_columns_clause.sql) (in query: SELECT COLUMNS('n') + COLUMNS('u') FROM (SELECT 1 AS a, 2 AS b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:28.262802 [ 35661 ] {4289fae3-2575-4431-9578-43f626d79f12} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT COLUMNS('n') + COLUMNS('u') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:28.423106 [ 35661 ] {a569c30e-c91b-428f-8448-1c4423394a01} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT COLUMNS('a|b') + COLUMNS('b') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58634) (comment: 00969_columns_clause.sql) (in query: SELECT COLUMNS('a|b') + COLUMNS('b') FROM (SELECT 1 AS a, 2 AS b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:28.424824 [ 35661 ] {a569c30e-c91b-428f-8448-1c4423394a01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT COLUMNS('a|b') + COLUMNS('b') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:30.931637 [ 1534 ] {045bc80c-1efa-497d-b005-a553aa67d3e7} executeQuery: Code: 117. DB::Exception: Incorrect state of aggregate function 'nothingNull', it should contain exactly one zero byte, while it is 1: In scope SELECT CAST('\0', 'AggregateFunction(nothingArrayIf, Array(Nullable(Nothing)), Nullable(Nothing))'). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58742) (comment: 02731_nothing_deserialization.sql) (in query: SELECT CAST('\x01\x00' AS AggregateFunction(nothingArrayIf, Array(Nullable(Nothing)), Nullable(Nothing)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned int&&) @ 0x000000002f6a704d 4. ./src/AggregateFunctions/AggregateFunctionNothing.h:101: DB::AggregateFunctionNothingImpl::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6a8fb1 5. ./src/AggregateFunctions/Combinators/AggregateFunctionArray.h:165: DB::AggregateFunctionArray::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fb92195 6. ./src/AggregateFunctions/Combinators/AggregateFunctionIf.h:199: DB::AggregateFunctionIf::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fc1e695 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fc50175 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 23. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 2025.06.18 11:16:30.933727 [ 1534 ] {045bc80c-1efa-497d-b005-a553aa67d3e7} TCPHandler: Code: 117. DB::Exception: Incorrect state of aggregate function 'nothingNull', it should contain exactly one zero byte, while it is 1: In scope SELECT CAST('\0', 'AggregateFunction(nothingArrayIf, Array(Nullable(Nothing)), Nullable(Nothing))'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned int&&) @ 0x000000002f6a704d 4. ./src/AggregateFunctions/AggregateFunctionNothing.h:101: DB::AggregateFunctionNothingImpl::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6a8fb1 5. ./src/AggregateFunctions/Combinators/AggregateFunctionArray.h:165: DB::AggregateFunctionArray::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fb92195 6. ./src/AggregateFunctions/Combinators/AggregateFunctionIf.h:199: DB::AggregateFunctionIf::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fc1e695 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fc50175 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 23. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 2025.06.18 11:16:31.103490 [ 35647 ] {0f6895e9-d30f-4d0f-9aad-f858c1701d61} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55474) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b EMPTY as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b77b 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:31.107160 [ 35647 ] {0f6895e9-d30f-4d0f-9aad-f858c1701d61} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b77b 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:31.726849 [ 35047 ] {363f3f36-6225-4814-a69c-8fc317de3287} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55482) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b POPULATE as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b511 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:31.729029 [ 35047 ] {363f3f36-6225-4814-a69c-8fc317de3287} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b511 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:32.350239 [ 35047 ] {22520ceb-0382-47ea-940e-0d638a522398} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58812) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b ENGINE = MergeTree() as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b3d1 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:32.352466 [ 35047 ] {22520ceb-0382-47ea-940e-0d638a522398} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b3d1 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:32.929708 [ 35659 ] {3d98ace8-5697-4804-b339-87518ec26e9a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38466). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38466) (comment: 01851_hedged_connections_external_tables.sql) (in query: DESC TABLE numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd963e 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:32.932901 [ 35659 ] {3d98ace8-5697-4804-b339-87518ec26e9a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38466). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:32.933171 [ 35659 ] {3d98ace8-5697-4804-b339-87518ec26e9a} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38466). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd963e 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:32.933968 [ 35659 ] {3d98ace8-5697-4804-b339-87518ec26e9a} TCPHandler: Client has gone away. 2025.06.18 11:16:32.965246 [ 35047 ] {ccc4146c-bf84-444e-ae15-a82fc1ca84b1} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58820) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa ENGINE = MergeTree() TO b as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b645 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:32.967441 [ 35047 ] {ccc4146c-bf84-444e-ae15-a82fc1ca84b1} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d09b645 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0a0e37 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0e0560 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0cf587 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d04ca4e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190411 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:33.110850 [ 35670 ] {3bc3e7db-99dc-4760-bab8-cdf795994682} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:49546). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49546) (comment: 01851_hedged_connections_external_tables.sql) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(2) AS `__table1` WHERE `__table1`.`number` GLOBAL IN (`_data_4785727355147348138_2762973006817880907` AS `__table2`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003abe937b 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd17b6 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:33.116679 [ 35670 ] {3bc3e7db-99dc-4760-bab8-cdf795994682} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:49546). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:16:33.116998 [ 35670 ] {3bc3e7db-99dc-4760-bab8-cdf795994682} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:49546). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003abe937b 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd17b6 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:33.117727 [ 35670 ] {3bc3e7db-99dc-4760-bab8-cdf795994682} TCPHandler: Client has gone away. 2025.06.18 11:16:33.299715 [ 1534 ] {02d044ae-e9c3-48b8-9502-90631431013f} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.301684 [ 1534 ] {02d044ae-e9c3-48b8-9502-90631431013f} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.327154 [ 1534 ] {6e7f705e-4971-4abe-92c4-ea9fcc4cf92a} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.328725 [ 1534 ] {6e7f705e-4971-4abe-92c4-ea9fcc4cf92a} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.352074 [ 1534 ] {3ebf0108-3d02-422a-88c4-f1d16573502b} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.353858 [ 1534 ] {3ebf0108-3d02-422a-88c4-f1d16573502b} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.378358 [ 1534 ] {de80e182-61b3-4e9a-9df5-586a39c8ac8c} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.380031 [ 1534 ] {de80e182-61b3-4e9a-9df5-586a39c8ac8c} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.405040 [ 1534 ] {7d904747-78a1-4c21-b8d4-fce008b2de54} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.406691 [ 1534 ] {7d904747-78a1-4c21-b8d4-fce008b2de54} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.431443 [ 1534 ] {4ccd98e5-4fd0-41b4-8222-dc9cd00f92e3} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.433141 [ 1534 ] {4ccd98e5-4fd0-41b4-8222-dc9cd00f92e3} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.460188 [ 1534 ] {3fde471a-12b6-4351-9bef-7be596aa21d5} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((5., 5.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((5.0, 5.0), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.461843 [ 1534 ] {3fde471a-12b6-4351-9bef-7be596aa21d5} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((5., 5.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.486925 [ 1534 ] {5452646e-daba-4011-b6ad-0ef3d06875ae} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42498) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:33.488466 [ 1534 ] {5452646e-daba-4011-b6ad-0ef3d06875ae} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4f4ee2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:38.748577 [ 35632 ] {7964a8cb-a101-4833-a0f5-d73991aabdcb} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00, current rows: 1.00 million: While executing Remote. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42816) (comment: 01882_scalar_subquery_exception.sql) (in query: select count() / (select count() from nums_in_mem_dist where rand() > 0) from system.one;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:38.750537 [ 35632 ] {7964a8cb-a101-4833-a0f5-d73991aabdcb} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00, current rows: 1.00 million: While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:39.147407 [ 1597 ] {f54c5041-a6ed-4625-9d48-6f987b26ee4a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55640). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55640) (comment: 01882_scalar_subquery_exception.sql) (in query: SELECT count() AS `count()` FROM `test_vjeqxi6f`.`nums_in_mem` AS `__table1` WHERE rand() > 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003abd5bfe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaeec9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:39.148275 [ 1597 ] {f54c5041-a6ed-4625-9d48-6f987b26ee4a} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55640). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003abd5bfe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaeec9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:39.148940 [ 1597 ] {f54c5041-a6ed-4625-9d48-6f987b26ee4a} TCPHandler: Client has gone away. 2025.06.18 11:16:41.691011 [ 35632 ] {ec18a6aa-573d-438e-b58e-a39920605493} executeQuery: Code: 12. DB::Exception: The bit position argument 8 is out of bounds for number: while executing 'FUNCTION bitTestAny(_CAST(85_UInt8, 'UInt8'_String) :: 1, __table1.number : 2) -> bitTestAny(_CAST(85_UInt8, 'UInt8'_String), __table1.number) UInt8 : 0'. (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42872) (comment: 01082_bit_test_out_of_bound.sql) (in query: SELECT number, bitTestAny(toUInt8(1 + 4 + 16 + 64), number) FROM numbers(8, 16);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. DB::PODArray, 63ul, 64ul> DB::FunctionBitTestMany::createMask(unsigned long, std::vector> const&) const @ 0x000000000d91d25a 5. DB::FunctionBitTestMany::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d90b0fa 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:41.693878 [ 35632 ] {ec18a6aa-573d-438e-b58e-a39920605493} TCPHandler: Code: 12. DB::Exception: The bit position argument 8 is out of bounds for number: while executing 'FUNCTION bitTestAny(_CAST(85_UInt8, 'UInt8'_String) :: 1, __table1.number : 2) -> bitTestAny(_CAST(85_UInt8, 'UInt8'_String), __table1.number) UInt8 : 0'. (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. DB::PODArray, 63ul, 64ul> DB::FunctionBitTestMany::createMask(unsigned long, std::vector> const&) const @ 0x000000000d91d25a 5. DB::FunctionBitTestMany::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d90b0fa 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:41.700709 [ 36046 ] {ee865bff-d2c3-4778-9517-f939864d6e5a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42884) (comment: 02480_analyzer_alias_nullptr.sql) (in query: SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x00000000334f11df 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1139: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033474cfc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:41.703090 [ 36046 ] {ee865bff-d2c3-4778-9517-f939864d6e5a} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x00000000334f11df 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1139: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033474cfc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:42.548807 [ 35632 ] {a820dc00-20dd-41de-8fb6-d45de18212f1} executeQuery: Code: 12. DB::Exception: The bit position argument 8 is out of bounds for number: while executing 'FUNCTION bitTestAll(_CAST(85_UInt8, 'UInt8'_String) :: 1, __table1.number : 2) -> bitTestAll(_CAST(85_UInt8, 'UInt8'_String), __table1.number) UInt8 : 0'. (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42872) (comment: 01082_bit_test_out_of_bound.sql) (in query: SELECT number, bitTestAll(toUInt8(1 + 4 + 16 + 64), number) FROM numbers(8, 16);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. DB::PODArray, 63ul, 64ul> DB::FunctionBitTestMany::createMask(unsigned long, std::vector> const&) const @ 0x000000000d8e07da 5. DB::FunctionBitTestMany::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d8ce2d3 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:42.551031 [ 35632 ] {a820dc00-20dd-41de-8fb6-d45de18212f1} TCPHandler: Code: 12. DB::Exception: The bit position argument 8 is out of bounds for number: while executing 'FUNCTION bitTestAll(_CAST(85_UInt8, 'UInt8'_String) :: 1, __table1.number : 2) -> bitTestAll(_CAST(85_UInt8, 'UInt8'_String), __table1.number) UInt8 : 0'. (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. DB::PODArray, 63ul, 64ul> DB::FunctionBitTestMany::createMask(unsigned long, std::vector> const&) const @ 0x000000000d8e07da 5. DB::FunctionBitTestMany::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d8ce2d3 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:43.613901 [ 35666 ] {317a45e3-c05d-4e3a-8df6-8c33e7fbefde} executeQuery: Code: 277. DB::Exception: Primary key (path) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42832) (comment: 03456_match_index_prefix_extraction.sql) (in query: SELECT count() FROM foo WHERE match(path, '^xxx\\|zzz') SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:43.615721 [ 35666 ] {317a45e3-c05d-4e3a-8df6-8c33e7fbefde} TCPHandler: Code: 277. DB::Exception: Primary key (path) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:43.718305 [ 16275 ] {ad4006e5-2ce7-40b0-a8c8-0ea7b090a4b7} executeQuery: Code: 69. DB::Exception: Scale 10 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT now64(10). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49838) (comment: 01259_datetime64_ubsan.sql) (in query: select now64(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032371b25 5. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x0000000015fa9a1b 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019acfb0e 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:43.718894 [ 35632 ] {faed08a4-a4b6-4537-92a1-61ac1ddc9f27} executeQuery: Code: 12. DB::Exception: The bit position argument needs to a positive value and less or equal to 7 for integer 85: while executing 'FUNCTION bitTest(_CAST(85_UInt8, 'UInt8'_String) :: 1, __table1.number : 2) -> bitTest(_CAST(85_UInt8, 'UInt8'_String), __table1.number) UInt8 : 0'. (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42872) (comment: 01082_bit_test_out_of_bound.sql) (in query: SELECT number, bitTest(toUInt8(1 + 4 + 16 + 64), number) FROM numbers(8, 16);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. char8_t DB::(anonymous namespace)::BitTestImpl::apply(char8_t, unsigned long) @ 0x000000000d687f4a 5. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned long const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d687b42 6. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_111BitTestImplENS12_11NameBitTestELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d70f199 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d6f0c42 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d6e15bb 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6dd848 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6d9efc 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:43.720063 [ 16275 ] {ad4006e5-2ce7-40b0-a8c8-0ea7b090a4b7} TCPHandler: Code: 69. DB::Exception: Scale 10 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT now64(10). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032371b25 5. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x0000000015fa9a1b 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019acfb0e 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:43.721257 [ 35632 ] {faed08a4-a4b6-4537-92a1-61ac1ddc9f27} TCPHandler: Code: 12. DB::Exception: The bit position argument needs to a positive value and less or equal to 7 for integer 85: while executing 'FUNCTION bitTest(_CAST(85_UInt8, 'UInt8'_String) :: 1, __table1.number : 2) -> bitTest(_CAST(85_UInt8, 'UInt8'_String), __table1.number) UInt8 : 0'. (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. char8_t DB::(anonymous namespace)::BitTestImpl::apply(char8_t, unsigned long) @ 0x000000000d687f4a 5. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned long const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d687b42 6. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_111BitTestImplENS12_11NameBitTestELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d70f199 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d6f0c42 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d6e15bb 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6dd848 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6d9efc 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:43.739341 [ 35666 ] {86cd80dd-57f0-41d6-a006-1105ed64414a} executeQuery: Code: 277. DB::Exception: Primary key (path) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42832) (comment: 03456_match_index_prefix_extraction.sql) (in query: SELECT count() FROM foo WHERE match(path, '^xxxx|foo') SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:43.741171 [ 35666 ] {86cd80dd-57f0-41d6-a006-1105ed64414a} TCPHandler: Code: 277. DB::Exception: Primary key (path) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:44.822322 [ 35632 ] {bf37441e-d6e4-4f9e-b767-40bc6af50023} executeQuery: Code: 12. DB::Exception: The bit position argument needs to a positive value and less or equal to 15 for integer 1: while executing 'FUNCTION bitTest(_CAST(1_UInt16, 'UInt16'_String) :: 1, negate(__table1.number) : 0) -> bitTest(_CAST(1_UInt16, 'UInt16'_String), negate(__table1.number)) UInt8 : 2'. (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:42872) (comment: 01082_bit_test_out_of_bound.sql) (in query: SELECT -number, bitTest(toUInt16(1), -number) FROM numbers(8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. char8_t DB::(anonymous namespace)::BitTestImpl::apply(unsigned short, long) @ 0x000000000d691e4a 5. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(unsigned short const*, long const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d691a23 6. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_111BitTestImplENS12_11NameBitTestELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS3_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d7371bf 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d6f0db9 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d6e15bb 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6dd848 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6d9efc 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:44.824803 [ 35632 ] {bf37441e-d6e4-4f9e-b767-40bc6af50023} TCPHandler: Code: 12. DB::Exception: The bit position argument needs to a positive value and less or equal to 15 for integer 1: while executing 'FUNCTION bitTest(_CAST(1_UInt16, 'UInt16'_String) :: 1, negate(__table1.number) : 0) -> bitTest(_CAST(1_UInt16, 'UInt16'_String), negate(__table1.number)) UInt8 : 2'. (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. char8_t DB::(anonymous namespace)::BitTestImpl::apply(unsigned short, long) @ 0x000000000d691e4a 5. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(unsigned short const*, long const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d691a23 6. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_111BitTestImplENS12_11NameBitTestELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS3_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d7371bf 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d6f0db9 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d6e15bb 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6dd848 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d6d9efc 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:45.601505 [ 35675 ] {9fe48c03-9100-45cb-b874-25efb9747c00} executeQuery: Code: 6. DB::Exception: Cannot parse string '61f0c404-5cb3-11e7-907b-a6006ad3dba0T' as UUID: syntax error at position 36 (parsed just '61f0c404-5cb3-11e7-907b-a6006ad3dba0'): In scope SELECT toUUID('61f0c404-5cb3-11e7-907b-a6006ad3dba0T'). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49898) (comment: 01528_to_uuid_or_null_or_zero.sql) (in query: SELECT toUUID('61f0c404-5cb3-11e7-907b-a6006ad3dba0T');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008f564bd 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f385df 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:16:45.603207 [ 35675 ] {9fe48c03-9100-45cb-b874-25efb9747c00} TCPHandler: Code: 6. DB::Exception: Cannot parse string '61f0c404-5cb3-11e7-907b-a6006ad3dba0T' as UUID: syntax error at position 36 (parsed just '61f0c404-5cb3-11e7-907b-a6006ad3dba0'): In scope SELECT toUUID('61f0c404-5cb3-11e7-907b-a6006ad3dba0T'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008f564bd 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f385df 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:16:45.915877 [ 35670 ] {68612ccf-2c6a-47bb-a46f-7955d0caedd4} executeQuery: Code: 714. DB::Exception: `cluster_for_parallel_replicas` setting refers to cluster with 2 shards. Expected a cluster with one shard. (UNEXPECTED_CLUSTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49920) (comment: 02982_parallel_replicas_unexpected_cluster.sql) (in query: SELECT count() FROM test_unexpected_cluster WHERE NOT ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:815: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x0000000036f6138c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6faa6 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:45.917646 [ 35670 ] {68612ccf-2c6a-47bb-a46f-7955d0caedd4} TCPHandler: Code: 714. DB::Exception: `cluster_for_parallel_replicas` setting refers to cluster with 2 shards. Expected a cluster with one shard. (UNEXPECTED_CLUSTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90580a 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:815: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x0000000036f6138c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6faa6 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:46.574371 [ 35675 ] {dda314df-872b-4290-8ac1-628821a9f19d} executeQuery: Code: 6. DB::Exception: Cannot parse string '61f0c404-5cb3-11e7-907b-a6006ad3dba0T' as UUID: syntax error at position 36 (parsed just '61f0c404-5cb3-11e7-907b-a6006ad3dba0'): while executing 'FUNCTION toUUID(__table1.value :: 1) -> toUUID(__table1.value) UUID : 0'. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49898) (comment: 01528_to_uuid_or_null_or_zero.sql) (in query: SELECT toUUID(value) FROM to_uuid_test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008f564bd 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f385df 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:46.576606 [ 35675 ] {dda314df-872b-4290-8ac1-628821a9f19d} TCPHandler: Code: 6. DB::Exception: Cannot parse string '61f0c404-5cb3-11e7-907b-a6006ad3dba0T' as UUID: syntax error at position 36 (parsed just '61f0c404-5cb3-11e7-907b-a6006ad3dba0'): while executing 'FUNCTION toUUID(__table1.value :: 1) -> toUUID(__table1.value) UUID : 0'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008f564bd 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f385df 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:47.348505 [ 35047 ] {e808bf4a-af04-4415-85a5-db4e17637889} executeQuery: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49984) (comment: 01202_array_auc_special.sql) (in query: SELECT arrayAUC([], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cddbecb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:47.350074 [ 35047 ] {e808bf4a-af04-4415-85a5-db4e17637889} TCPHandler: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cddbecb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:47.445345 [ 33053 ] {243f35a8-d9e5-474f-b56b-8ec8f4c11372} executeQuery: Code: 128. DB::Exception: Suspiciously many rows in Native format: 2178749300044435230: While executing Native. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50036) (comment: 02687_native_fuzz.sql) (in query: -- It correctly throws exception about incorrect data instead of a low-level exception about the allocator: SELECT * FROM format(Native, 'WatchID Int64, JavaEnable Int16, UTMCaTitle String, GoodEvent Int16, EventTime DateTime, EventDate Date, Countem String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int16', $$ žžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžž‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûURLHashInt64Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Ž oâïòeý€ à#â\X-h³ýX vÀvÍÀ‰Çh˜´9›DÍ|3úÐb.‹CLIDInt32ä$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad727c5 5. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:41: DB::NativeInputFormat::read() @ 0x000000003b2f160a 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 7. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 16. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:16:47.447747 [ 33053 ] {243f35a8-d9e5-474f-b56b-8ec8f4c11372} TCPHandler: Code: 128. DB::Exception: Suspiciously many rows in Native format: 2178749300044435230: While executing Native. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad727c5 5. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:41: DB::NativeInputFormat::read() @ 0x000000003b2f160a 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 7. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 16. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:16:47.568298 [ 35047 ] {a00b08e2-2128-45b1-b234-2a16baeec2f4} executeQuery: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([1], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49984) (comment: 01202_array_auc_special.sql) (in query: SELECT arrayAUC([1], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cddbecb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:47.570106 [ 35047 ] {a00b08e2-2128-45b1-b234-2a16baeec2f4} TCPHandler: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([1], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cddbecb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:47.591726 [ 35047 ] {c9eda216-aa55-4630-8820-b91846db8eb7} executeQuery: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49984) (comment: 01202_array_auc_special.sql) (in query: SELECT arrayAUC([], [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cddbecb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:47.593295 [ 35047 ] {c9eda216-aa55-4630-8820-b91846db8eb7} TCPHandler: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cddbecb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:48.385714 [ 35047 ] {c5769e22-e08e-48fe-bb19-11b98e5284cf} executeQuery: Code: 36. DB::Exception: Array arguments for function arrayAUC must have equal sizes: In scope SELECT arrayAUC([1, 2], [3]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49984) (comment: 01202_array_auc_special.sql) (in query: SELECT arrayAUC([1, 2], [3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cddb117 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:48.387662 [ 35047 ] {c5769e22-e08e-48fe-bb19-11b98e5284cf} TCPHandler: Code: 36. DB::Exception: Array arguments for function arrayAUC must have equal sizes: In scope SELECT arrayAUC([1, 2], [3]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cddb117 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:48.406911 [ 35047 ] {54a4a148-2123-4f8d-9659-0922a85ac14f} executeQuery: Code: 36. DB::Exception: Array arguments for function arrayAUC must have equal sizes: In scope SELECT arrayAUC([1], [2, 3]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49984) (comment: 01202_array_auc_special.sql) (in query: SELECT arrayAUC([1], [2, 3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cddb117 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:48.408380 [ 35047 ] {54a4a148-2123-4f8d-9659-0922a85ac14f} TCPHandler: Code: 36. DB::Exception: Array arguments for function arrayAUC must have equal sizes: In scope SELECT arrayAUC([1], [2, 3]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cddb117 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:48.760966 [ 35669 ] {b5e3c3b1-9ccc-4be1-a5c0-9981fcf2f09a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'Y' in scope SELECT * FROM (SELECT [1, 2, 3] AS x, [4, 5, 6] AS y) ARRAY JOIN x, Y. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50088) (comment: 03071_analyzer_array_join_forbid_non_existing_columns.sql) (in query: SELECT * FROM ( SELECT [1, 2, 3] AS x, [4, 5, 6] AS y ) ARRAY JOIN x, Y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e015c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e137a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:48.762810 [ 35669 ] {b5e3c3b1-9ccc-4be1-a5c0-9981fcf2f09a} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'Y' in scope SELECT * FROM (SELECT [1, 2, 3] AS x, [4, 5, 6] AS y) ARRAY JOIN x, Y. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e015c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e137a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:49.630327 [ 35674 ] {765e2d0a-464f-4d1b-b53a-b8200d08bf6b} executeQuery: Code: 36. DB::Exception: Argument 'format/NOSIGN' must be a literal with type String, got Array. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50108) (comment: 02245_s3_schema_desc.sql) (in query: SELECT * FROM s3(decodeURLComponent(NULL), [NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x0000000038d298f7 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x0000000038d27bad 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:31: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000038d27059 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030ab78b5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002fef0bac 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fef4e17 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:49.632355 [ 35674 ] {765e2d0a-464f-4d1b-b53a-b8200d08bf6b} TCPHandler: Code: 36. DB::Exception: Argument 'format/NOSIGN' must be a literal with type String, got Array. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x0000000038d298f7 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x0000000038d27bad 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:31: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000038d27059 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000030ab78b5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000309f0a43 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002fef0bac 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fef4e17 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:50.436302 [ 31332 ] {5fefb940-690e-46fa-9795-fa97ec2726cb} executeQuery: Code: 141. DB::Exception: Storage test_pi8ce7wr.modify_sample doesn't support sampling. (SAMPLING_NOT_SUPPORTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50172) (comment: 01430_modify_sample_by_zookeeper_long.sql) (in query: SELECT count(), min(x), max(x), sum(x), uniqExact(x) FROM modify_sample SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:837: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033437425 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e147a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:50.438174 [ 31332 ] {5fefb940-690e-46fa-9795-fa97ec2726cb} TCPHandler: Code: 141. DB::Exception: Storage test_pi8ce7wr.modify_sample doesn't support sampling. (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:837: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033437425 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e147a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:51.169019 [ 31332 ] {a0ad6ebb-40ce-4f4c-ae07-8744887f2cc2} executeQuery: Code: 141. DB::Exception: Storage test_pi8ce7wr.modify_sample_replicated doesn't support sampling. (SAMPLING_NOT_SUPPORTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50172) (comment: 01430_modify_sample_by_zookeeper_long.sql) (in query: SELECT count(), min(x), max(x), sum(x), uniqExact(x) FROM modify_sample_replicated SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:837: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033437425 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e147a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:51.170758 [ 31332 ] {a0ad6ebb-40ce-4f4c-ae07-8744887f2cc2} TCPHandler: Code: 141. DB::Exception: Storage test_pi8ce7wr.modify_sample_replicated doesn't support sampling. (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:837: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033437425 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e147a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:51.432181 [ 1597 ] {9c4f7599-db05-48b6-9fe9-4b032ee8a763} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function divide: argument of numeric type cannot be first: In scope SELECT 2 / (1, 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT 2 / (1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::FunctionBinaryArithmetic::getFunctionForTupleAndNumberArithmetic(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000000e67cfdb 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea1eb92 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:16:51.434105 [ 1597 ] {9c4f7599-db05-48b6-9fe9-4b032ee8a763} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function divide: argument of numeric type cannot be first: In scope SELECT 2 / (1, 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::FunctionBinaryArithmetic::getFunctionForTupleAndNumberArithmetic(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000000e67cfdb 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea1eb92 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:16:52.152103 [ 31332 ] {4d3e9d4e-4410-419c-a2d6-8d25e152418a} executeQuery: Code: 36. DB::Exception: Sampling expression must be present in the primary key. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50172) (comment: 01430_modify_sample_by_zookeeper_long.sql) (in query: ALTER TABLE modify_sample_replicated MODIFY SAMPLE BY d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:219: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x00000000396ab821 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000397503bb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:52.153699 [ 31332 ] {4d3e9d4e-4410-419c-a2d6-8d25e152418a} TCPHandler: Code: 36. DB::Exception: Sampling expression must be present in the primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:219: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x00000000396ab821 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000397503bb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.647310 [ 31332 ] {411217f1-6995-4210-a2d0-985be508f237} executeQuery: Code: 36. DB::Exception: ALTER MODIFY SAMPLE BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50172) (comment: 01430_modify_sample_by_zookeeper_long.sql) (in query: ALTER TABLE modify_sample_old MODIFY SAMPLE BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039757715 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.649217 [ 31332 ] {411217f1-6995-4210-a2d0-985be508f237} TCPHandler: Code: 36. DB::Exception: ALTER MODIFY SAMPLE BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039757715 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.655326 [ 35673 ] {605c0200-ad8d-4579-85b7-390b1b8af4e1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51364) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.666612 [ 35673 ] {605c0200-ad8d-4579-85b7-390b1b8af4e1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.694945 [ 1534 ] {2c1e00b3-b3d9-479b-a41e-e8b265b07ecf} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51394) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.697338 [ 1534 ] {2c1e00b3-b3d9-479b-a41e-e8b265b07ecf} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.703151 [ 35659 ] {dbac2faa-8d24-4b6c-a419-9da1feda4597} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51408) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.705730 [ 35659 ] {dbac2faa-8d24-4b6c-a419-9da1feda4597} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.910297 [ 35005 ] {9335a9ad-609e-42d4-9ef6-fd695481636e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51444) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:53.912574 [ 35005 ] {9335a9ad-609e-42d4-9ef6-fd695481636e} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.260488 [ 35675 ] {ad62d285-c973-4bae-a7a4-d96e8ac61166} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51372) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.260496 [ 35664 ] {fedae50f-ef3d-44ef-bce6-244ca742cfdc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51412) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.263505 [ 35664 ] {fedae50f-ef3d-44ef-bce6-244ca742cfdc} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.279141 [ 35675 ] {ad62d285-c973-4bae-a7a4-d96e8ac61166} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.429327 [ 1590 ] {4b1d6eaa-1981-4965-99ab-536f52a10205} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51464) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.432018 [ 1590 ] {4b1d6eaa-1981-4965-99ab-536f52a10205} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.461962 [ 16275 ] {9f0ae0c9-d4d2-478f-93bb-a72ef115006b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51516) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.464303 [ 16275 ] {9f0ae0c9-d4d2-478f-93bb-a72ef115006b} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.597361 [ 35047 ] {efe157f0-8ac5-4d0c-a411-19e2fd27d1c9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51398) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:54.612807 [ 35047 ] {efe157f0-8ac5-4d0c-a411-19e2fd27d1c9} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:55.298583 [ 35632 ] {ae6d5c75-7935-48c1-b859-62bbf967eee4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51640) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:55.309519 [ 35669 ] {65f6f36e-de54-49a2-8204-41bbdf2ce78f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51612) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:55.312347 [ 35669 ] {65f6f36e-de54-49a2-8204-41bbdf2ce78f} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:55.316902 [ 35632 ] {ae6d5c75-7935-48c1-b859-62bbf967eee4} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:55.873287 [ 35632 ] {74574d2e-31a5-4d1e-8f85-17f372484fd1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51732) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:55.888903 [ 35632 ] {74574d2e-31a5-4d1e-8f85-17f372484fd1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:56.016150 [ 35671 ] {d3a0d618-8aa1-4e7c-b5d9-e5f7ec196cef} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51760) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:56.016960 [ 35673 ] {7728fe17-34ac-45de-bfef-bade986b3e77} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51754) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:56.018733 [ 35671 ] {d3a0d618-8aa1-4e7c-b5d9-e5f7ec196cef} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:56.033544 [ 35673 ] {7728fe17-34ac-45de-bfef-bade986b3e77} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:56.456838 [ 1597 ] {9a9958e3-594c-41bf-8204-2003adb163f3} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got UInt8: In scope SELECT L1Norm(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT L1Norm(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionLNorm::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ca56e92 5. DB::TupleOrArrayFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ca4a96e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:56.458828 [ 1597 ] {9a9958e3-594c-41bf-8204-2003adb163f3} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got UInt8: In scope SELECT L1Norm(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionLNorm::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ca56e92 5. DB::TupleOrArrayFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ca4a96e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:57.243722 [ 35661 ] {ebed5a9e-35b0-4e23-a7a9-200ce252064c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51886) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:57.264095 [ 35661 ] {ebed5a9e-35b0-4e23-a7a9-200ce252064c} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:57.459199 [ 35675 ] {bbfd6592-5643-49d7-afb2-454eedc905c4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51936) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:57.462013 [ 35675 ] {bbfd6592-5643-49d7-afb2-454eedc905c4} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:57.511730 [ 36047 ] {8ace237c-4497-437a-9edb-4ce0605da6bc} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT (t.1).3 FROM t_tuple_numeric. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51642) (comment: 02286_tuple_numeric_identifier.sql) (in query: SELECT t.1.3 FROM t_tuple_numeric;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93cb33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93af92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:57.513668 [ 36047 ] {8ace237c-4497-437a-9edb-4ce0605da6bc} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT (t.1).3 FROM t_tuple_numeric. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93cb33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93af92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:57.536891 [ 36047 ] {11c2a360-0fba-4d06-aa18-94adc8cb5f05} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '4': In scope SELECT t.4 FROM t_tuple_numeric. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51642) (comment: 02286_tuple_numeric_identifier.sql) (in query: SELECT t.4 FROM t_tuple_numeric;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93cb33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93af92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:57.538800 [ 36047 ] {11c2a360-0fba-4d06-aa18-94adc8cb5f05} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '4': In scope SELECT t.4 FROM t_tuple_numeric. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46368a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93cb33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93af92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:57.592647 [ 36047 ] {6d411896-2c00-41ec-bcf9-a0ce5c6deeee} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 't.1.1' in scope SELECT t.`1`.`1`, t.`1`.`2`, t.`2` FROM t_tuple_numeric. Maybe you meant: ['t.1.3']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51642) (comment: 02286_tuple_numeric_identifier.sql) (in query: SELECT `t`.`1`.`1`, `t`.`1`.`2`, `t`.`2` FROM t_tuple_numeric;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:57.600675 [ 36047 ] {6d411896-2c00-41ec-bcf9-a0ce5c6deeee} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 't.1.1' in scope SELECT t.`1`.`1`, t.`1`.`2`, t.`2` FROM t_tuple_numeric. Maybe you meant: ['t.1.3']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.438626 [ 31332 ] {c7e82349-15fd-4fe6-890b-178564928d5f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52040) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.441052 [ 31332 ] {c7e82349-15fd-4fe6-890b-178564928d5f} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.531799 [ 1597 ] {0a55f6df-a71d-4679-8aa3-15ef1fb83ca7} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and String of arguments of function divide: In scope SELECT (1, 1) / toString(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT (1, 1) / toString(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea20d47 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:58.545367 [ 1597 ] {0a55f6df-a71d-4679-8aa3-15ef1fb83ca7} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and String of arguments of function divide: In scope SELECT (1, 1) / toString(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea20d47 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:16:58.594546 [ 35670 ] {7d1f1521-235f-412d-a0a4-92b9c6696d7f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52122) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.596963 [ 35670 ] {7d1f1521-235f-412d-a0a4-92b9c6696d7f} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.611376 [ 35047 ] {f05d46fd-fc2d-4734-9af6-47065fc0398a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52136) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.645048 [ 35047 ] {f05d46fd-fc2d-4734-9af6-47065fc0398a} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.866925 [ 1534 ] {bca4273c-769c-4519-9556-fcd38a0fb620} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52124) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.869576 [ 1534 ] {bca4273c-769c-4519-9556-fcd38a0fb620} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.874623 [ 16279 ] {efad9da6-8206-40be-9311-5a0e315f37f3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52038) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.883138 [ 35005 ] {3deed696-aec8-4116-a134-209c1ee48395} executeQuery: Code: 36. DB::Exception: TTL expression toDate('2020-01-01') does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51982) (comment: 01652_ttl_old_syntax.sql) (in query: ALTER TABLE ttl_old_syntax MODIFY TTL toDate('2020-01-01');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/TTLDescription.cpp:68: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038cdfe84 5. ./build_docker/./src/Storages/TTLDescription.cpp:0: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038ce2ce6 6. ./build_docker/./src/Storages/AlterCommands.cpp:801: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003807bf36 7. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.884983 [ 35005 ] {3deed696-aec8-4116-a134-209c1ee48395} TCPHandler: Code: 36. DB::Exception: TTL expression toDate('2020-01-01') does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/TTLDescription.cpp:68: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038cdfe84 5. ./build_docker/./src/Storages/TTLDescription.cpp:0: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038ce2ce6 6. ./build_docker/./src/Storages/AlterCommands.cpp:801: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003807bf36 7. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.892058 [ 16279 ] {efad9da6-8206-40be-9311-5a0e315f37f3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.897165 [ 35659 ] {3d61cefe-fae3-4b80-8909-a5b814cb5e13} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52138) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.899618 [ 35659 ] {3d61cefe-fae3-4b80-8909-a5b814cb5e13} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.900834 [ 36000 ] {017c6954-8c5e-4256-b3f4-7171f078b3a2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52150) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.928153 [ 1590 ] {eaf2e1e1-2287-4489-b000-0c533f3a9560} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52160) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.928965 [ 36000 ] {017c6954-8c5e-4256-b3f4-7171f078b3a2} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.938747 [ 612 ] {dc32ee13-82ba-4b5d-b97b-6c3fb5682310} executeQuery: Code: 36. DB::Exception: Connection pool cannot have zero size. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51296) (comment: 02479_mysql_connect_to_self.sql) (in query: SELECT count() FROM mysql('127.0.0.1:9004', currentDatabase(), foo, 'default', '[HIDDEN]', SETTINGS connection_pool_size = 0)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:30: DB::createMySQLPoolWithFailover(String const&, std::vector, std::allocator>> const&, String const&, String const&, DB::MySQLSettings const&) @ 0x000000003929552d 5. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:17: DB::createMySQLPoolWithFailover(DB::StorageMySQL::Configuration const&, DB::MySQLSettings const&) @ 0x00000000392952a7 6. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:0: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fea57fb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.940695 [ 612 ] {dc32ee13-82ba-4b5d-b97b-6c3fb5682310} TCPHandler: Code: 36. DB::Exception: Connection pool cannot have zero size. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:30: DB::createMySQLPoolWithFailover(String const&, std::vector, std::allocator>> const&, String const&, String const&, DB::MySQLSettings const&) @ 0x000000003929552d 5. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:17: DB::createMySQLPoolWithFailover(DB::StorageMySQL::Configuration const&, DB::MySQLSettings const&) @ 0x00000000392952a7 6. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:0: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fea57fb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:58.960973 [ 1590 ] {eaf2e1e1-2287-4489-b000-0c533f3a9560} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.046259 [ 35661 ] {fa83f2ce-1dfb-460e-b855-910958a3553a} executeQuery: Code: 394. DB::Exception: Query 'fa83f2ce-1dfb-460e-b855-910958a3553a' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52076) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.079055 [ 35661 ] {fa83f2ce-1dfb-460e-b855-910958a3553a} TCPHandler: Code: 394. DB::Exception: Query 'fa83f2ce-1dfb-460e-b855-910958a3553a' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.658092 [ 35675 ] {ae55c78d-c281-4522-9897-fead69ba83af} executeQuery: Code: 394. DB::Exception: Query 'ae55c78d-c281-4522-9897-fead69ba83af' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52254) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.692945 [ 35675 ] {ae55c78d-c281-4522-9897-fead69ba83af} TCPHandler: Code: 394. DB::Exception: Query 'ae55c78d-c281-4522-9897-fead69ba83af' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.711955 [ 16275 ] {23e9b3bd-d711-40d0-9b77-5a737a58c02e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52238) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.745030 [ 16275 ] {23e9b3bd-d711-40d0-9b77-5a737a58c02e} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.748226 [ 36046 ] {a1e9327e-63e3-48eb-8e9f-bb8cce1e612a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52256) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:16:59.750821 [ 36046 ] {a1e9327e-63e3-48eb-8e9f-bb8cce1e612a} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.005440 [ 35659 ] {a6125069-1074-4734-9c09-4ad07471bbc1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52290) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.040905 [ 35659 ] {a6125069-1074-4734-9c09-4ad07471bbc1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.317164 [ 35671 ] {ccf51809-2299-4fa0-8141-f79fa2121746} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52346) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.345198 [ 35671 ] {ccf51809-2299-4fa0-8141-f79fa2121746} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.349136 [ 35636 ] {19fe6c35-45e6-47e9-b809-4c370a00c558} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52360) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.366978 [ 35636 ] {19fe6c35-45e6-47e9-b809-4c370a00c558} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.685246 [ 1597 ] {7685c274-5aed-4e72-b6ce-1c5b7b0a5f66} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function negate: While executing function tupleNegate for tuple element 1: In scope SELECT -(1, toString(1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT -(1, toString(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018d82e7f 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018d4b743 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. DB::FunctionTupleNegate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c9dccb0 12. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 16. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018d823dc 17. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018d4b743 18. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 19. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 20. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 21. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 22. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 24. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 27. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 2025.06.18 11:17:00.687002 [ 1597 ] {7685c274-5aed-4e72-b6ce-1c5b7b0a5f66} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function negate: While executing function tupleNegate for tuple element 1: In scope SELECT -(1, toString(1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018d82e7f 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018d4b743 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. DB::FunctionTupleNegate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c9dccb0 12. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 16. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018d823dc 17. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018d4b743 18. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 19. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 20. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 21. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 22. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 24. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 27. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 2025.06.18 11:17:00.898980 [ 35671 ] {2f2baec0-d04b-448c-8efd-f234cd327524} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52458) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.931201 [ 35671 ] {2f2baec0-d04b-448c-8efd-f234cd327524} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.931989 [ 1534 ] {bd71a192-1400-454b-a026-f5cb6732c0ab} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52462) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:00.965053 [ 1534 ] {bd71a192-1400-454b-a026-f5cb6732c0ab} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.387966 [ 35632 ] {875fc510-5b33-428c-a114-7dca826de74e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52482) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.420886 [ 35632 ] {875fc510-5b33-428c-a114-7dca826de74e} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.470793 [ 1534 ] {930648da-2b9d-4841-b4df-93c78019ca00} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52520) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.489469 [ 1534 ] {930648da-2b9d-4841-b4df-93c78019ca00} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.501253 [ 35636 ] {2bb74de9-d158-4df9-9f55-52538529a250} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52478) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.503551 [ 35636 ] {2bb74de9-d158-4df9-9f55-52538529a250} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.857905 [ 31332 ] {82674c12-2b0b-4218-acd1-c080ea8447a8} executeQuery: Code: 394. DB::Exception: Query '82674c12-2b0b-4218-acd1-c080ea8447a8' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59896) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.866105 [ 35657 ] {0a4ab053-f497-4442-847b-06870fcd3568} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59886) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.868528 [ 35657 ] {0a4ab053-f497-4442-847b-06870fcd3568} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.891908 [ 31332 ] {82674c12-2b0b-4218-acd1-c080ea8447a8} TCPHandler: Code: 394. DB::Exception: Query '82674c12-2b0b-4218-acd1-c080ea8447a8' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.953570 [ 35673 ] {064873a7-34f1-48fc-aab6-bf8f7ba102fb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59904) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:01.956150 [ 35673 ] {064873a7-34f1-48fc-aab6-bf8f7ba102fb} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.103130 [ 1590 ] {dee40f79-eb78-4925-b103-a996a1b8d283} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52312) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized (toDate(DateTime) is always monotonic, but we cannot relaxing the predicates to do trivial count()) select count() from test1 where p > toDateTime('2020-09-01 10:00:00');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.105089 [ 1590 ] {dee40f79-eb78-4925-b103-a996a1b8d283} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.206899 [ 1597 ] {4dfffd8c-c7e0-421d-a48f-1dce3f44de20} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2), toDecimal32(2, 4)). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2), toDecimal32(2, 4));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b65b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:02.229012 [ 1597 ] {4dfffd8c-c7e0-421d-a48f-1dce3f44de20} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2), toDecimal32(2, 4)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b65b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:02.766914 [ 35657 ] {5eeb088e-0eba-47cc-bf37-b9730d94c9d2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59974) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.784880 [ 35657 ] {5eeb088e-0eba-47cc-bf37-b9730d94c9d2} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.803172 [ 35661 ] {0dc93d59-048f-48cd-9a3f-0282743042a2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60002) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.818913 [ 35661 ] {0dc93d59-048f-48cd-9a3f-0282743042a2} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.867079 [ 35669 ] {170f5512-94b2-46c9-b343-67f1018904ee} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59966) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:02.869426 [ 35669 ] {170f5512-94b2-46c9-b343-67f1018904ee} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.050310 [ 1590 ] {223f3f69-b5ed-49bc-b975-2f096c41a1eb} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52312) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized (some predicate depends on non-partition_expr columns) select count() FROM test1 where toDate(p) = '2020-09-01' and k = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.052250 [ 1590 ] {223f3f69-b5ed-49bc-b975-2f096c41a1eb} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.062756 [ 35674 ] {ade509fd-a208-4c8e-9740-ed4a9323666a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60000) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.065323 [ 35674 ] {ade509fd-a208-4c8e-9740-ed4a9323666a} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.439264 [ 35659 ] {d25a9dbb-8409-4d93-bdc8-10085bb682c3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60086) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.442144 [ 35659 ] {d25a9dbb-8409-4d93-bdc8-10085bb682c3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.537666 [ 36000 ] {b3b7c336-9587-4645-96d0-e518b5efe502} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60090) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.537666 [ 35664 ] {0e276152-f8f2-4d92-b3cf-10c7aed005a6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60072) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.539865 [ 35664 ] {0e276152-f8f2-4d92-b3cf-10c7aed005a6} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:03.540810 [ 36000 ] {b3b7c336-9587-4645-96d0-e518b5efe502} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.013198 [ 1597 ] {17e2b379-7b2a-43f7-b7cc-a63134db2816} executeQuery: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function cosineDistance, got Tuple(UInt8, UInt8) and Tuple(UInt8, UInt8, UInt8): In scope SELECT cosineDistance((1, 2), (2, 3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT cosineDistance((1, 2), (2, 3, 4));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::(anonymous namespace)::checkAndGetTuplesSize(std::shared_ptr const&, std::shared_ptr const&, String const&) @ 0x000000001c97ef08 5. DB::FunctionCosineDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000001cadf314 6. DB::TupleOrArrayFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001cacf3ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:17:04.026863 [ 1597 ] {17e2b379-7b2a-43f7-b7cc-a63134db2816} TCPHandler: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function cosineDistance, got Tuple(UInt8, UInt8) and Tuple(UInt8, UInt8, UInt8): In scope SELECT cosineDistance((1, 2), (2, 3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::(anonymous namespace)::checkAndGetTuplesSize(std::shared_ptr const&, std::shared_ptr const&, String const&) @ 0x000000001c97ef08 5. DB::FunctionCosineDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000001cadf314 6. DB::TupleOrArrayFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001cacf3ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:17:04.037990 [ 1534 ] {ef626a64-f025-4a58-adcb-fc140f1a4442} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60146) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.048973 [ 1534 ] {ef626a64-f025-4a58-adcb-fc140f1a4442} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.095662 [ 1597 ] {8e0a7705-546a-4464-85dc-536cf9b90164} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm((1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: -- TODO: what's the expected value of () + ()? Currently it returns 0. -- SELECT tuple() + tuple(); -- { serverError NUMBER_OF_ARGUMENTS_DOESNT_MATCH } SELECT LpNorm((1, 2, 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.102250 [ 1597 ] {8e0a7705-546a-4464-85dc-536cf9b90164} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm((1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.139519 [ 1597 ] {c80f96a8-2389-495c-8f43-52722a3af2c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(1, 2, -1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT max2(1, 2, -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.176689 [ 1597 ] {c80f96a8-2389-495c-8f43-52722a3af2c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(1, 2, -1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.311127 [ 35659 ] {7b32d663-9b30-4b3d-b1d0-9ae05b91bda9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60156) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.320910 [ 35659 ] {7b32d663-9b30-4b3d-b1d0-9ae05b91bda9} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.407900 [ 35664 ] {72b7848d-b8de-4500-9f42-1a32fb7b1084} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60152) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.414569 [ 35664 ] {72b7848d-b8de-4500-9f42-1a32fb7b1084} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.762466 [ 35632 ] {dc47b91e-ce71-4054-88b1-c251b5619d05} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60200) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.830208 [ 35632 ] {dc47b91e-ce71-4054-88b1-c251b5619d05} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:04.992457 [ 36000 ] {d0afff61-f292-4760-ad20-07059eeee5e7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60252) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.028848 [ 36000 ] {d0afff61-f292-4760-ad20-07059eeee5e7} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.080021 [ 35669 ] {3ca6b311-03d0-4d93-8e11-fa636d588299} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60284) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.112888 [ 35669 ] {3ca6b311-03d0-4d93-8e11-fa636d588299} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.180253 [ 33053 ] {995aa62a-a36e-43cc-b95a-370f78247c4d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60272) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.182534 [ 33053 ] {995aa62a-a36e-43cc-b95a-370f78247c4d} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.294742 [ 1590 ] {ba1c1eda-864a-433e-98f1-26f12a477b1b} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52312) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized select count() from test_tuple array join [p,p] as c where toDate(p) = '2020-09-01';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.296722 [ 1590 ] {ba1c1eda-864a-433e-98f1-26f12a477b1b} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.661211 [ 1590 ] {c6012c40-aedb-40b1-899b-870cdec81bad} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52312) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized select count() from test_tuple array join [1,2,3] as c where toDate(p) = '2020-09-01';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.663159 [ 1590 ] {c6012c40-aedb-40b1-899b-870cdec81bad} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.691281 [ 36000 ] {8203a945-bcd1-42b4-90e8-a94ffa16fc70} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60330) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.693694 [ 36000 ] {8203a945-bcd1-42b4-90e8-a94ffa16fc70} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.742081 [ 1597 ] {1ab62a00-6efe-4012-b8ec-c1257bdf5823} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), materialize(4.));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b46b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:05.744072 [ 1597 ] {1ab62a00-6efe-4012-b8ec-c1257bdf5823} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b46b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:06.134849 [ 35005 ] {8f4052d5-c8a9-484e-88ec-d95e769dd45f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60410) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:06.147653 [ 35005 ] {8f4052d5-c8a9-484e-88ec-d95e769dd45f} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:06.443637 [ 1590 ] {8e25fca4-ab1e-4f99-83a3-db40129c18da} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52312) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized select count() from test_two_args where i = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:06.447314 [ 1590 ] {8e25fca4-ab1e-4f99-83a3-db40129c18da} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:07.049036 [ 1597 ] {aaf34a0d-5d8b-418c-a1b6-beb8b0874f65} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpDistance(tuple(*, 1), tuple(2, *), * + 1.) FROM numbers(3, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b46b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. DB::FunctionLDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cab5eb1 12. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cab32c2 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 23. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 24. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 25. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:07.051237 [ 1597 ] {aaf34a0d-5d8b-418c-a1b6-beb8b0874f65} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b46b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. DB::FunctionLDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cab5eb1 12. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cab32c2 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 23. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 24. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 25. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:07.583631 [ 35664 ] {201d069e-ece6-41ed-90ca-7dbfc30a956c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60634) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:07.586670 [ 35664 ] {201d069e-ece6-41ed-90ca-7dbfc30a956c} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:07.696373 [ 35674 ] {5f286937-7b48-4c83-81ef-1f2a72771684} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60694) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:07.698917 [ 35632 ] {3750fa86-d989-430b-8ebc-a5c2f17c00b4} executeQuery: Code: 394. DB::Exception: Query '3750fa86-d989-430b-8ebc-a5c2f17c00b4' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60678) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:07.708157 [ 35632 ] {3750fa86-d989-430b-8ebc-a5c2f17c00b4} TCPHandler: Code: 394. DB::Exception: Query '3750fa86-d989-430b-8ebc-a5c2f17c00b4' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:07.715830 [ 35674 ] {5f286937-7b48-4c83-81ef-1f2a72771684} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:08.174181 [ 35671 ] {a9afb107-d1d3-4c6f-8344-26e9d7808426} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60792) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:08.188983 [ 35671 ] {a9afb107-d1d3-4c6f-8344-26e9d7808426} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:08.541410 [ 1597 ] {239d6e10-ff36-4d80-8989-cba98e1475dd} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((3, 1, 4), 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((3, 1, 4), 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.543973 [ 1597 ] {239d6e10-ff36-4d80-8989-cba98e1475dd} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((3, 1, 4), 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.568664 [ 1597 ] {de4ced8a-d331-4463-abea-810822f658a6} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.5). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), 0.5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.570428 [ 1597 ] {de4ced8a-d331-4463-abea-810822f658a6} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.5). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.592212 [ 1597 ] {dea50742-392e-495c-84dd-a8c040affd83} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), inf). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.593986 [ 1597 ] {dea50742-392e-495c-84dd-a8c040affd83} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), inf). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.615910 [ 1597 ] {a5a449e7-1129-4456-9f5b-70fe71fbe8b5} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), -1.). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), -1.);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.617670 [ 1597 ] {a5a449e7-1129-4456-9f5b-70fe71fbe8b5} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.663562 [ 1597 ] {9cca90c2-5071-4a39-921d-61e27129cf29} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2, 3), -1). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b65b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.665506 [ 1597 ] {9cca90c2-5071-4a39-921d-61e27129cf29} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2, 3), -1). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b65b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.708210 [ 36000 ] {2b84e78a-095a-45da-8065-222384f8b3a8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60838) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:08.711219 [ 36047 ] {c1dea6f5-0531-4242-8c85-ee6c961a52f4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60850) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:08.714884 [ 36047 ] {c1dea6f5-0531-4242-8c85-ee6c961a52f4} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:08.724806 [ 1597 ] {a7a76134-8749-47d4-8aaa-a49cc5516f40} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50182) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), 0.);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:08.724890 [ 36000 ] {2b84e78a-095a-45da-8065-222384f8b3a8} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:08.726661 [ 1597 ] {a7a76134-8749-47d4-8aaa-a49cc5516f40} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca8b27b 5. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ca7eec2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:09.105941 [ 33053 ] {24f841ed-95b4-48d9-8254-31d51f86559f} executeQuery: Code: 394. DB::Exception: Query '24f841ed-95b4-48d9-8254-31d51f86559f' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60922) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.116830 [ 35047 ] {652435ec-8a33-40e0-a6b2-0d2ece507303} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60936) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.116893 [ 16275 ] {f757d558-c7be-4070-8dd2-31a01c49c8b3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60896) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.119465 [ 16275 ] {f757d558-c7be-4070-8dd2-31a01c49c8b3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.132880 [ 35047 ] {652435ec-8a33-40e0-a6b2-0d2ece507303} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.139527 [ 33053 ] {24f841ed-95b4-48d9-8254-31d51f86559f} TCPHandler: Code: 394. DB::Exception: Query '24f841ed-95b4-48d9-8254-31d51f86559f' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.168517 [ 35659 ] {3da56311-5638-4b59-a252-2fcea12a19ac} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60898) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.173174 [ 35659 ] {3da56311-5638-4b59-a252-2fcea12a19ac} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.345190 [ 35005 ] {9e0e7ac0-a2e2-4dce-bccc-76947bb1a31b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60948) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.373023 [ 35005 ] {9e0e7ac0-a2e2-4dce-bccc-76947bb1a31b} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.872657 [ 35659 ] {3c6a2463-dbda-4639-b4e3-8d44d4720c23} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32782) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:09.904942 [ 35659 ] {3c6a2463-dbda-4639-b4e3-8d44d4720c23} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.517040 [ 35670 ] {c0704aa0-75e5-4ba2-9a4f-32d1029548e1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32874) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.532892 [ 35670 ] {c0704aa0-75e5-4ba2-9a4f-32d1029548e1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.615771 [ 35657 ] {a29666ea-b2ff-4e53-a677-c5b8df1642d5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32858) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.645060 [ 35657 ] {a29666ea-b2ff-4e53-a677-c5b8df1642d5} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.834184 [ 35047 ] {724012bd-686b-42b7-bf8c-4ffee2cf35a7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32894) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.858153 [ 16275 ] {22939f05-be36-41e2-91ff-53db0ee5b633} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32878) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.872850 [ 16275 ] {22939f05-be36-41e2-91ff-53db0ee5b633} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:10.895923 [ 35047 ] {724012bd-686b-42b7-bf8c-4ffee2cf35a7} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.121093 [ 35664 ] {fac85925-dafb-468e-b050-6d59c787536f} executeQuery: Code: 394. DB::Exception: Query 'fac85925-dafb-468e-b050-6d59c787536f' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32928) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.153017 [ 35664 ] {fac85925-dafb-468e-b050-6d59c787536f} TCPHandler: Code: 394. DB::Exception: Query 'fac85925-dafb-468e-b050-6d59c787536f' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.341816 [ 35659 ] {f0be2fd5-f116-47d3-b98a-9ae7fcbdd622} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32984) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.344479 [ 35659 ] {f0be2fd5-f116-47d3-b98a-9ae7fcbdd622} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.682216 [ 35666 ] {09f24d21-4469-4d6e-86cd-7928da150b39} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33030) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.712728 [ 35666 ] {09f24d21-4469-4d6e-86cd-7928da150b39} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.918092 [ 36000 ] {76651651-46a8-42a9-aef1-971135c13b16} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50362) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:11.948911 [ 36000 ] {76651651-46a8-42a9-aef1-971135c13b16} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:12.803314 [ 35047 ] {483fcccc-c9c8-4647-bc62-b8b16f68d744} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50472) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:12.823141 [ 35047 ] {483fcccc-c9c8-4647-bc62-b8b16f68d744} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:13.577105 [ 35661 ] {c5acb6cc-6516-46ec-be80-0d3e9f9203a1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50596) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:13.605106 [ 35661 ] {c5acb6cc-6516-46ec-be80-0d3e9f9203a1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.235733 [ 35661 ] {9af25c6e-040f-49ac-aeab-b29255109942} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50706) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.252930 [ 35661 ] {9af25c6e-040f-49ac-aeab-b29255109942} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.266472 [ 36046 ] {2b37d2f6-e27d-4177-b35d-b031091276d8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50726) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.301005 [ 36046 ] {2b37d2f6-e27d-4177-b35d-b031091276d8} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.383790 [ 35636 ] {c318ddcd-010d-4ffc-a523-99aa42b3e84e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50734) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.403689 [ 35636 ] {c318ddcd-010d-4ffc-a523-99aa42b3e84e} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.480838 [ 35669 ] {cb773bee-7313-4e5c-bfd0-42806c8b15fa} executeQuery: Code: 394. DB::Exception: Query 'cb773bee-7313-4e5c-bfd0-42806c8b15fa' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50762) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:14.483479 [ 35669 ] {cb773bee-7313-4e5c-bfd0-42806c8b15fa} TCPHandler: Code: 394. DB::Exception: Query 'cb773bee-7313-4e5c-bfd0-42806c8b15fa' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:15.706671 [ 33053 ] {662ebf17-2768-41b8-91b6-b7492e05fc9d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50960) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:15.709257 [ 33053 ] {662ebf17-2768-41b8-91b6-b7492e05fc9d} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:15.785103 [ 1597 ] {e03acb1d-9bf9-436c-917a-1b145b03e1d0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50950) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:15.787370 [ 1597 ] {e03acb1d-9bf9-436c-917a-1b145b03e1d0} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:15.961170 [ 35664 ] {ef4bc02c-fd0f-48fa-8483-5eac7396dee5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50990) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:15.976216 [ 35005 ] {5aa9efe1-c91f-4bd0-be58-d57f59ee37d0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51018) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:15.992999 [ 35664 ] {ef4bc02c-fd0f-48fa-8483-5eac7396dee5} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:16.015201 [ 35005 ] {5aa9efe1-c91f-4bd0-be58-d57f59ee37d0} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:16.119421 [ 35047 ] {c54aa9ad-f82e-4193-9978-53c7d93da11d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51042) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:16.161006 [ 35047 ] {c54aa9ad-f82e-4193-9978-53c7d93da11d} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:16.573186 [ 35670 ] {272b0497-e2fc-47ed-99bb-7890ef2cbffc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51094) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:16.576311 [ 35670 ] {272b0497-e2fc-47ed-99bb-7890ef2cbffc} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.165481 [ 35636 ] {731fa66b-f31b-4a71-a044-9879fee359ca} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51196) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.180936 [ 35636 ] {731fa66b-f31b-4a71-a044-9879fee359ca} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.237132 [ 35670 ] {54560364-f137-48e4-a1e3-b440d3b62356} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51188) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.239475 [ 35670 ] {54560364-f137-48e4-a1e3-b440d3b62356} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.245785 [ 35661 ] {67b74f06-1a73-4b7a-bc08-701fad83e617} executeQuery: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51134) (comment: 01036_union_different_columns.sql) (in query: select 1 as c1, 2 as c2, 3 as c3 union all (select 1 as c1, 2 as c2, 3 as c3 union all select 1 as c1, 2 as c2) -- { serverError UNION_ALL_RESULT_STRUCTURES_MISMATCH } ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000033370057 4. ./build_docker/./src/Planner/Utils.cpp:95: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x00000000333638a6 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForUnionNode() @ 0x0000000034ceef4e 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd4b 7. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.261655 [ 35661 ] {67b74f06-1a73-4b7a-bc08-701fad83e617} TCPHandler: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000033370057 4. ./build_docker/./src/Planner/Utils.cpp:95: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x00000000333638a6 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForUnionNode() @ 0x0000000034ceef4e 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd4b 7. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.279137 [ 35671 ] {159c005e-8971-4099-8657-6843ae5c14cb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51206) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.292784 [ 35671 ] {159c005e-8971-4099-8657-6843ae5c14cb} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.338956 [ 35659 ] {67aa6033-c176-4307-b73c-2d7dffd72d70} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51240) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.341610 [ 35657 ] {c03ca725-191f-46ed-a238-db3feca18584} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51202) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.343529 [ 612 ] {16257c4a-c7fe-43dc-a080-00e05db6027d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51254) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.343981 [ 35657 ] {c03ca725-191f-46ed-a238-db3feca18584} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.360875 [ 612 ] {16257c4a-c7fe-43dc-a080-00e05db6027d} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.371947 [ 35659 ] {67aa6033-c176-4307-b73c-2d7dffd72d70} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.408818 [ 36046 ] {99ef35a2-46cb-40fc-b0c1-1d355a226506} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51258) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.449274 [ 36046 ] {99ef35a2-46cb-40fc-b0c1-1d355a226506} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:17.984157 [ 36047 ] {4e3ac51e-c1e8-4cc2-9818-8c281ff06a93} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51314) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.009657 [ 36047 ] {4e3ac51e-c1e8-4cc2-9818-8c281ff06a93} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.677357 [ 35661 ] {c9db2a1d-3841-4b3b-8ebe-87d624860d67} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51442) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.680596 [ 35661 ] {c9db2a1d-3841-4b3b-8ebe-87d624860d67} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.728174 [ 35636 ] {caeb4592-9e18-444a-ac24-623c572b175d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51456) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.764894 [ 35636 ] {caeb4592-9e18-444a-ac24-623c572b175d} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.822330 [ 36000 ] {ed9ae123-d6b9-493b-9c5c-8c3154e87dcb} executeQuery: Code: 394. DB::Exception: Query 'ed9ae123-d6b9-493b-9c5c-8c3154e87dcb' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51480) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.826476 [ 36000 ] {ed9ae123-d6b9-493b-9c5c-8c3154e87dcb} TCPHandler: Code: 394. DB::Exception: Query 'ed9ae123-d6b9-493b-9c5c-8c3154e87dcb' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ac25d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.830164 [ 1590 ] {58493dc2-9dae-4eaf-a2bf-6467cb386663} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51510) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.851013 [ 1590 ] {58493dc2-9dae-4eaf-a2bf-6467cb386663} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.923302 [ 612 ] {5e3596ba-0414-43bc-993f-3d6bc1d19b34} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51514) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:18.925752 [ 612 ] {5e3596ba-0414-43bc-993f-3d6bc1d19b34} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:19.670234 [ 31332 ] {97a8bff0-7fe5-4954-85fb-dc5b5bf3c8fd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51666) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:19.696869 [ 31332 ] {97a8bff0-7fe5-4954-85fb-dc5b5bf3c8fd} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.062059 [ 1534 ] {9afca127-dbb1-4da6-871a-7fe3a3f5a06c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51716) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.084354 [ 35005 ] {43f1dd30-769c-454f-b9d9-ad54a44eaa07} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51732) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.087212 [ 1534 ] {9afca127-dbb1-4da6-871a-7fe3a3f5a06c} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb4d69 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aeb6d8b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0e85 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.147308 [ 35005 ] {43f1dd30-769c-454f-b9d9-ad54a44eaa07} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.154533 [ 35664 ] {7c6307f2-be23-4d3b-ae54-d0cde4d228d8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51700) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.157702 [ 35664 ] {7c6307f2-be23-4d3b-ae54-d0cde4d228d8} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.549939 [ 35670 ] {5aad6482-f25a-4283-9884-5193ffb2ba61} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51798) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.576982 [ 35670 ] {5aad6482-f25a-4283-9884-5193ffb2ba61} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.971913 [ 1597 ] {f906efe3-8c60-413f-bd03-c97b0fb8e63d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51864) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:20.990830 [ 1597 ] {f906efe3-8c60-413f-bd03-c97b0fb8e63d} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:21.158161 [ 35047 ] {1c919b0a-0dc6-4a12-a741-8385d3ba3f94} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51948) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:21.176012 [ 35047 ] {1c919b0a-0dc6-4a12-a741-8385d3ba3f94} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a78f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:21.910200 [ 35675 ] {98584895-5925-46b4-af0b-9146f3643bd7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41252) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:21.931227 [ 35675 ] {98584895-5925-46b4-af0b-9146f3643bd7} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae792d6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 9. ? @ 0x00007f8e6ce63ac3 10. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:22.014624 [ 35671 ] {c565a7f7-4089-4fbc-8224-5fceb84e2571} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41268) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:22.027275 [ 35671 ] {c565a7f7-4089-4fbc-8224-5fceb84e2571} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:22.182720 [ 36046 ] {518599d3-9f36-46f4-96e0-17c2ef0262c3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41300) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:22.212882 [ 36046 ] {518599d3-9f36-46f4-96e0-17c2ef0262c3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003501386d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae79bce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7948a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 10. ? @ 0x00007f8e6ce63ac3 11. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:22.218127 [ 1590 ] {ea111c54-3352-4372-81e2-dbd3bb64e4e3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41304) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:22.220909 [ 1590 ] {ea111c54-3352-4372-81e2-dbd3bb64e4e3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000035012f1e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003ae784c6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322b2567 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc4f8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a35766 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a1f9c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:22.714648 [ 36047 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41324, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:22.715067 [ 16275 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41332, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:22.809464 [ 35632 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41408, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/VarInt.h:95: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x0000000020181528 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x00000000201f3d12 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000003abc8c73 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abab338 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:23.035281 [ 35675 ] {2217b3a7-3dc5-44ba-8446-43adca64f1a1} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41386, local: [::1]:9000). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41386) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_dn1smrjv' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003abe10f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0ee4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:23.042903 [ 35675 ] {2217b3a7-3dc5-44ba-8446-43adca64f1a1} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41386). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:23.043230 [ 35675 ] {2217b3a7-3dc5-44ba-8446-43adca64f1a1} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41386, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003abe10f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0ee4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:23.044005 [ 35675 ] {2217b3a7-3dc5-44ba-8446-43adca64f1a1} TCPHandler: Client has gone away. 2025.06.18 11:17:26.160511 [ 1254 ] {00aefe8a-ffbb-41f9-bb98-02e45f9c9a58::all_1_1_0_7} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:26.223430 [ 31332 ] {a9a94448-444c-41a8-abf6-ca0165bc6640} executeQuery: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41556) (comment: 03015_with_fill_invalid_expression.sql) (in query: select number as x, number + 1 as y from numbers(5) where number % 3 == 1 order by y, x with fill from 1 to 4, y with fill from 2 to 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:252: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003bde85db 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003bddc693 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003bddb685 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000003223199c 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000032231406 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000032288521 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003bdd9a94 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1f6cd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:26.225298 [ 31332 ] {a9a94448-444c-41a8-abf6-ca0165bc6640} TCPHandler: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:252: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003bde85db 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003bddc693 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003bddb685 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000003223199c 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000032231406 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000032288521 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003bdd9a94 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1f6cd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:26.570281 [ 35666 ] {4c34e61c-7d6d-40ca-8068-2d1471703327} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41464) (comment: 01788_update_nested_type_subcolumn_check.sql) (in query: alter table test_wide_nested update `info.id` = [100,200], `info.age` = [10,20,30], `info.name` = ['a','b','c'] where id = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfec9f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfea05 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2dd319 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2e07b5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:26.572420 [ 35666 ] {4c34e61c-7d6d-40ca-8068-2d1471703327} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfec9f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfea05 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2dd319 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2e07b5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:26.931473 [ 1254 ] {00aefe8a-ffbb-41f9-bb98-02e45f9c9a58::all_1_1_0_7} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000001c966067 4. DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c9651b0 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3ad7fc 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 31. ? @ 0x00007f8e6ce63ac3 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:27.692225 [ 1242 ] {d2833a26-e0c9-491a-a2f1-a7007a43f97c::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:27.694023 [ 35666 ] {ab9851b0-8e9f-4033-b052-d856d4a22e3e} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41464) (comment: 01788_update_nested_type_subcolumn_check.sql) (in query: alter table test_wide_nested update `info.id` = [100,200,300], `info.age` = [10,20,30] where id = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfec9f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfea05 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2dd319 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2e07b5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:27.696049 [ 35666 ] {ab9851b0-8e9f-4033-b052-d856d4a22e3e} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfec9f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfea05 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2dd319 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2e07b5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:27.698413 [ 1242 ] {d2833a26-e0c9-491a-a2f1-a7007a43f97c::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000001c966067 4. DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c9651b0 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3ad7fc 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 31. ? @ 0x00007f8e6ce63ac3 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:33.325862 [ 16275 ] {6179b23b-c952-4426-b27d-3e3a0a4c337d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53250) (comment: 02874_toDaysSinceYearZero.sql) (in query: SELECT toDaysSinceYearZero();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f79fc 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:33.327793 [ 16275 ] {6179b23b-c952-4426-b27d-3e3a0a4c337d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f79fc 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:34.139033 [ 16275 ] {bc870b9d-f3e8-4d2e-82d7-a46ac4b7b5b7} executeQuery: Code: 43. DB::Exception: Function toDaysSinceYearZero supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toDaysSinceYearZero(toDate('2023-09-08'), 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53250) (comment: 02874_toDaysSinceYearZero.sql) (in query: SELECT toDaysSinceYearZero(toDate('2023-09-08'), 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f7d94 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:34.140856 [ 16275 ] {bc870b9d-f3e8-4d2e-82d7-a46ac4b7b5b7} TCPHandler: Code: 43. DB::Exception: Function toDaysSinceYearZero supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toDaysSinceYearZero(toDate('2023-09-08'), 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f7d94 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:34.925546 [ 16275 ] {7e593a69-8fc0-4a55-876a-a2186f7ee624} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero('str'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53250) (comment: 02874_toDaysSinceYearZero.sql) (in query: SELECT toDaysSinceYearZero('str');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f80d3 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:34.927514 [ 16275 ] {7e593a69-8fc0-4a55-876a-a2186f7ee624} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero('str'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f80d3 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:34.951064 [ 16275 ] {62e5b7d7-4dfc-4945-97c1-35f1858e9452} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero(42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53250) (comment: 02874_toDaysSinceYearZero.sql) (in query: SELECT toDaysSinceYearZero(42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f80d3 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:34.953267 [ 16275 ] {62e5b7d7-4dfc-4945-97c1-35f1858e9452} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero(42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001c5f80d3 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c5f23f8 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:41.609822 [ 16275 ] {4dcd5c95-020b-42f6-9f29-64c0ee0a7392} executeQuery: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53468) (comment: 01459_default_value_of_argument_type_nullptr_dereference.sql) (in query: SELECT defaultValueOfTypeName(FQDN());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df5fca8 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:17:41.611500 [ 16275 ] {4dcd5c95-020b-42f6-9f29-64c0ee0a7392} TCPHandler: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df5fca8 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:17:43.372248 [ 1597 ] {1b477854-be41-4369-83ba-48f00ccf8435} executeQuery: Code: 252. DB::Exception: Too many parts (5 with average size of 153.00 B) in table 'test_p8e4j8md.test_02521_insert_delay (353f4499-00b1-4760-b408-f90dd39a4d60)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55840) (comment: 02521_incorrect_dealy_for_insert_bug_44902.sh) (in query: INSERT INTO test_02521_insert_delay VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:43.375700 [ 1597 ] {1b477854-be41-4369-83ba-48f00ccf8435} TCPHandler: Code: 252. DB::Exception: Too many parts (5 with average size of 153.00 B) in table 'test_p8e4j8md.test_02521_insert_delay (353f4499-00b1-4760-b408-f90dd39a4d60)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:46.529573 [ 1534 ] {61711044-2355-4a2a-b3bd-3fd5531fcbfc} executeQuery: Code: 62. DB::Exception: Empty query: In scope SELECT formatQuery(''). (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55934) (comment: 02882_formatQuery.sql) (in query: SELECT formatQuery('');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:46.531227 [ 1534 ] {61711044-2355-4a2a-b3bd-3fd5531fcbfc} TCPHandler: Code: 62. DB::Exception: Empty query: In scope SELECT formatQuery(''). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:46.552657 [ 1534 ] {efbded50-fe07-458b-92c4-d40d55f390eb} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('SEECTwrong'): SEECTwrong. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: In scope SELECT formatQuery('SEECTwrong'). (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55934) (comment: 02882_formatQuery.sql) (in query: SELECT formatQuery('SEECTwrong');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:46.554308 [ 1534 ] {efbded50-fe07-458b-92c4-d40d55f390eb} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('SEECTwrong'): SEECTwrong. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: In scope SELECT formatQuery('SEECTwrong'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:47.395805 [ 1534 ] {a2f40c32-0269-48f0-b05b-354e99828287} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('bad'): bad 3. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: while executing 'FUNCTION formatQuery(__table1.query : 2) -> formatQuery(__table1.query) String : 1'. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55934) (comment: 02882_formatQuery.sql) (in query: SELECT id, query, formatQuery(query) FROM some_invalid ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:47.398640 [ 1534 ] {a2f40c32-0269-48f0-b05b-354e99828287} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('bad'): bad 3. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: while executing 'FUNCTION formatQuery(__table1.query : 2) -> formatQuery(__table1.query) String : 1'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:47.973275 [ 1534 ] {cb7b6f68-7810-4a9f-a70d-e53a769398a3} executeQuery: Code: 62. DB::Exception: Empty query: In scope SELECT formatQuerySingleLine(''). (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55934) (comment: 02882_formatQuery.sql) (in query: SELECT formatQuerySingleLine('');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:47.974862 [ 1534 ] {cb7b6f68-7810-4a9f-a70d-e53a769398a3} TCPHandler: Code: 62. DB::Exception: Empty query: In scope SELECT formatQuerySingleLine(''). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:47.991978 [ 1534 ] {70fa8549-da66-4e8c-a13c-ec73937e721b} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('SEECTwrong'): SEECTwrong. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: In scope SELECT formatQuerySingleLine('SEECTwrong'). (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55934) (comment: 02882_formatQuery.sql) (in query: SELECT formatQuerySingleLine('SEECTwrong');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:47.993442 [ 1534 ] {70fa8549-da66-4e8c-a13c-ec73937e721b} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('SEECTwrong'): SEECTwrong. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: In scope SELECT formatQuerySingleLine('SEECTwrong'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:17:48.108375 [ 1534 ] {b2a90f62-1fa9-48ad-ad96-ee456db89828} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('bad'): bad 3. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: while executing 'FUNCTION formatQuerySingleLine(__table1.query : 2) -> formatQuerySingleLine(__table1.query) String : 1'. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55934) (comment: 02882_formatQuery.sql) (in query: SELECT id, query, formatQuerySingleLine(query) FROM some_invalid ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:48.111124 [ 1534 ] {b2a90f62-1fa9-48ad-ad96-ee456db89828} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('bad'): bad 3. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE: while executing 'FUNCTION formatQuerySingleLine(__table1.query : 2) -> formatQuerySingleLine(__table1.query) String : 1'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fadb65c 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:48.632664 [ 1275 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:49.335158 [ 1273 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:49.635566 [ 1272 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:50.077346 [ 1276 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:50.322707 [ 36000 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:519: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000003399ac77 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x000000003374a06f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003ababff3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:50.332116 [ 35669 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:519: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000003399ac77 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x000000003374a06f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003ababff3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:50.991615 [ 1279 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:51.161576 [ 612 ] {e8752e87-7981-48dd-97e5-277243c9c6f9} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56154) (comment: 03034_dynamic_conversions.sql) (in query: select number::Dynamic::Array(UInt64) as v from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::(anonymous namespace)::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000008714153 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086cb14a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000086d53f5 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:51.163410 [ 612 ] {e8752e87-7981-48dd-97e5-277243c9c6f9} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::(anonymous namespace)::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000008714153 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086cb14a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000086d53f5 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:51.396710 [ 1278 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:51.835275 [ 35674 ] {672868e1-fe6d-4f05-8d51-1467d2817b60} executeQuery: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56236) (comment: 01333_select_abc_asterisk.sql) (in query: --error: should be failed for abc.*; select abc.*;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348930b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be0d6 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:51.837053 [ 35674 ] {672868e1-fe6d-4f05-8d51-1467d2817b60} TCPHandler: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348930b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be0d6 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:51.857213 [ 35674 ] {f98178df-58af-4b2b-b524-567bdab5779e} executeQuery: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT *, abc.*. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56236) (comment: 01333_select_abc_asterisk.sql) (in query: select *, abc.*;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348930b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be0d6 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:51.859024 [ 35674 ] {f98178df-58af-4b2b-b524-567bdab5779e} TCPHandler: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT *, abc.*. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348930b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be0d6 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:51.877420 [ 35674 ] {bbebdc14-7287-45df-a873-9a48b375ae22} executeQuery: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*, *. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56236) (comment: 01333_select_abc_asterisk.sql) (in query: select abc.*, *;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348930b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be0d6 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:51.879122 [ 35674 ] {bbebdc14-7287-45df-a873-9a48b375ae22} TCPHandler: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*, *. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348930b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334be0d6 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442d83 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:52.125921 [ 1264 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:52.810506 [ 1270 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:53.128186 [ 1267 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:53.440840 [ 612 ] {46b3d0b1-21b3-47c5-8939-098dac5a4dbe} executeQuery: Code: 6. DB::Exception: Cannot parse string '42.42' as UInt64: syntax error at position 2 (parsed just '42'). Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.d :: 2, 'UInt64'_String :: 1) -> CAST(__table1.d, 'UInt64'_String) UInt64 : 0'. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56154) (comment: 03034_dynamic_conversions.sql) (in query: select d::UInt64 from test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000086d5481 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:53.443268 [ 612 ] {46b3d0b1-21b3-47c5-8939-098dac5a4dbe} TCPHandler: Code: 6. DB::Exception: Cannot parse string '42.42' as UInt64: syntax error at position 2 (parsed just '42'). Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.d :: 2, 'UInt64'_String :: 1) -> CAST(__table1.d, 'UInt64'_String) UInt64 : 0'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000086d5481 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:53.905561 [ 1271 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:54.187076 [ 1276 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:54.318181 [ 36000 ] {9e3e9c4f-ca49-4a0b-b947-12e9c7d43618} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39234) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT ([12,13] % [5,6]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000176c3d67 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016cff939 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:54.320038 [ 36000 ] {9e3e9c4f-ca49-4a0b-b947-12e9c7d43618} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000176c3d67 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016cff939 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:17:54.704847 [ 612 ] {8d07b2f8-fc7a-4d91-bf39-c12a7c5fc15b} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: while executing 'FUNCTION CAST(__table1.d :: 2, 'Date'_String :: 1) -> CAST(__table1.d, 'Date'_String) Date : 0'. (CANNOT_PARSE_DATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56154) (comment: 03034_dynamic_conversions.sql) (in query: select d::Date from test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201d0e67 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000961c593 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009327df0 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009318f7f 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000086d5481 15. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:54.707026 [ 612 ] {8d07b2f8-fc7a-4d91-bf39-c12a7c5fc15b} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: while executing 'FUNCTION CAST(__table1.d :: 2, 'Date'_String :: 1) -> CAST(__table1.d, 'Date'_String) Date : 0'. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201d0e67 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000961c593 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009327df0 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009318f7f 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000086d5481 15. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:54.950783 [ 35664 ] {38744555-26b3-4922-a8d8-330b0bea3dbd} executeQuery: Code: 290. DB::Exception: Limit would be exceeded by inserting 2 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39276) (comment: 02418_keeper_map_keys_limit.sql) (in query: INSERT INTO 02418_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000035c89597 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:249: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003853fd9b 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003853c8df 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003853c657 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:171: DB::StorageKeeperMapSink::onFinish() @ 0x0000000038538e5f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:54.953103 [ 35664 ] {38744555-26b3-4922-a8d8-330b0bea3dbd} TCPHandler: Code: 290. DB::Exception: Limit would be exceeded by inserting 2 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000035c89597 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:249: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003853fd9b 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003853c8df 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003853c657 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:171: DB::StorageKeeperMapSink::onFinish() @ 0x0000000038538e5f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:55.142098 [ 35664 ] {7d31cb43-51bd-4e6a-9058-988da6613876} executeQuery: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39276) (comment: 02418_keeper_map_keys_limit.sql) (in query: INSERT INTO 02418_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000035c89597 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:249: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003853fd9b 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003853c8df 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003853c657 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:171: DB::StorageKeeperMapSink::onFinish() @ 0x0000000038538e5f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:55.144104 [ 35664 ] {7d31cb43-51bd-4e6a-9058-988da6613876} TCPHandler: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000035c89597 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:249: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003853fd9b 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003853c8df 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003853c657 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:171: DB::StorageKeeperMapSink::onFinish() @ 0x0000000038538e5f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:55.174929 [ 36000 ] {09875f81-2fc1-477d-9e69-a4c8e946f56b} executeQuery: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39234) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT ([2,3,4]-[1,-2,10,29]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168c2f3c 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000168b4c4f 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168addfd 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168a971c 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168bff22 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000168b4c4f 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168addfd 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168a971c 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:17:55.176746 [ 36000 ] {09875f81-2fc1-477d-9e69-a4c8e946f56b} TCPHandler: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168c2f3c 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000168b4c4f 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168addfd 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168a971c 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168bff22 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000168b4c4f 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168addfd 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000168a971c 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:17:55.198575 [ 1266 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:55.421862 [ 35664 ] {2a491623-38a9-494d-8991-4d9d9ce9ded3} executeQuery: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39276) (comment: 02418_keeper_map_keys_limit.sql) (in query: INSERT INTO 02418_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000035c89597 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:249: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003853fd9b 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003853c8df 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003853c657 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:171: DB::StorageKeeperMapSink::onFinish() @ 0x0000000038538e5f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:55.424215 [ 35664 ] {2a491623-38a9-494d-8991-4d9d9ce9ded3} TCPHandler: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000035c89597 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:249: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003853fd9b 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003853c8df 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003853c657 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:171: DB::StorageKeeperMapSink::onFinish() @ 0x0000000038538e5f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:56.148809 [ 36000 ] {f8a2a0b9-925f-411e-9da0-b419e7505457} executeQuery: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39234) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT x, y, x+y FROM a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a0a851c 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a09a22f 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a092bf0 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:56.151591 [ 36000 ] {f8a2a0b9-925f-411e-9da0-b419e7505457} TCPHandler: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a0a851c 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a09a22f 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a092bf0 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:56.161494 [ 1275 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02369%2F02370_lost_part_intersecting_merges_test_oxv821gc%2Ftest_oxv821gc%2Freplicas%2F2&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:57.345249 [ 35664 ] {77293bed-2b5c-416e-a66a-d92563fb36d2} executeQuery: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39332) (comment: 01817_storage_buffer_parameters.sql) (in query: -- not enough args create table buffer_01817 (key Int) Engine=Buffer(currentDatabase(), data_01817, /* num_layers= */ 1, /* min_time= */ 1, /* max_time= */ 86400, /* min_rows= */ 1e9, /* max_rows= */ 1e6, /* min_bytes= */ 0 /* max_bytes= 4e6 */ );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038dd5677 5. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:57.347473 [ 35664 ] {77293bed-2b5c-416e-a66a-d92563fb36d2} TCPHandler: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038dd5677 5. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:57.370199 [ 35664 ] {d58d2f8e-7947-49c9-9183-833936ff01a5} executeQuery: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39332) (comment: 01817_storage_buffer_parameters.sql) (in query: -- too much args create table buffer_01817 (key Int) Engine=Buffer(currentDatabase(), data_01817, /* num_layers= */ 1, /* min_time= */ 1, /* max_time= */ 86400, /* min_rows= */ 1e9, /* max_rows= */ 1e6, /* min_bytes= */ 0, /* max_bytes= */ 4e6, /* flush_time= */ 86400, /* flush_rows= */ 10, /* flush_bytes= */0, 0 );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038dd5677 5. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:57.372034 [ 35664 ] {d58d2f8e-7947-49c9-9183-833936ff01a5} TCPHandler: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038dd5677 5. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:59.262149 [ 35664 ] {6374cca6-39c4-4eca-8c37-3c816cc5ff23} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_i531ueew.table_for_alter (6c351a58-2469-4f76-af97-d68371038422)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39418) (comment: 02280_add_query_level_settings.sql) (in query: INSERT INTO table_for_alter VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:59.264168 [ 35664 ] {6374cca6-39c4-4eca-8c37-3c816cc5ff23} TCPHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_i531ueew.table_for_alter (6c351a58-2469-4f76-af97-d68371038422)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:59.334773 [ 35664 ] {11ba36e7-4523-4080-a215-da7c15dbe30d} executeQuery: Code: 252. DB::Exception: Too many parts (2 with average size of 320.00 B) in table 'test_i531ueew.table_for_alter (6c351a58-2469-4f76-af97-d68371038422)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39418) (comment: 02280_add_query_level_settings.sql) (in query: INSERT INTO table_for_alter VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:59.336914 [ 35664 ] {11ba36e7-4523-4080-a215-da7c15dbe30d} TCPHandler: Code: 252. DB::Exception: Too many parts (2 with average size of 320.00 B) in table 'test_i531ueew.table_for_alter (6c351a58-2469-4f76-af97-d68371038422)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a398adb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:17:59.794867 [ 850 ] {} test_oxv821gc.rmt1 (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/6dc/6dc07280-8d80-40fc-b0c3-dd8c77c18eac/all_1_2_1/columns.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x00000000201471ef 4. ./contrib/llvm-project/libcxx/include/optional:344: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000020146945 5. ./build_docker/./src/IO/OpenedFile.cpp:40: DB::OpenedFile::getFD() const @ 0x000000003072b776 6. ./src/IO/ReadBufferFromFile.h:0: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x0000000030715c42 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x0000000030714523 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x0000000030714131 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000032eabf9d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000393a8e35 11. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:135: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x000000003a28dd3d 12. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:419: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x000000003a28d1ed 13. ./contrib/llvm-project/libcxx/include/__tree:1055: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x000000003a0899bc 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x000000003a091b21 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x000000003a0998a1 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a09b87f 17. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:17:59.795392 [ 850 ] {} test_oxv821gc.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_1_2_1 looks broken. Removing it and will try to fetch. 2025.06.18 11:17:59.795911 [ 850 ] {} test_oxv821gc.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_1_2_1 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.06.18 11:17:59.797602 [ 850 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): Detached 1 parts covered by broken part all_1_2_1: all_1_2_1 2025.06.18 11:18:00.284982 [ 35005 ] {deca7b81-89a9-4a00-afd4-f9bde73935d7} executeQuery: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/6dc/6dc07280-8d80-40fc-b0c3-dd8c77c18eac/all_1_2_1/data.bin: , errno: 2, strerror: No such file or directory: (while reading from part /var/lib/clickhouse/store/6dc/6dc07280-8d80-40fc-b0c3-dd8c77c18eac/all_1_2_1/ in table test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (FILE_DOESNT_EXIST) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39424) (comment: 02370_lost_part_intersecting_merges.sh) (in query: select * from rmt1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x00000000201471ef 4. ./contrib/llvm-project/libcxx/include/optional:344: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000020146945 5. ./build_docker/./src/IO/OpenedFile.cpp:40: DB::OpenedFile::getFD() const @ 0x000000003072b776 6. ./src/IO/AsynchronousReadBufferFromFile.h:0: DB::AsynchronousReadBufferFromFileWithDescriptorsCache::AsynchronousReadBufferFromFileWithDescriptorsCache(DB::IAsynchronousReader&, Priority, String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000003071c8a2 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x0000000030714fc3 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x0000000030714131 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000032eabf9d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000393a8e35 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:80: std::unique_ptr> std::__function::__policy_invoker> ()>::__call_impl> ()>>(std::__function::__policy_storage const*) @ 0x0000000039cd86b0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::CachedCompressedReadBuffer::initInput() @ 0x0000000039cda263 13. ./src/Compression/CachedCompressedReadBuffer.h:65: non-virtual thunk to DB::CachedCompressedReadBuffer::setReadUntilPosition(unsigned long) @ 0x0000000039ce0403 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:0: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039cd3424 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cc90ac 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c95352 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb8b36 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb1273 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf55eb4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 2025.06.18 11:18:00.290153 [ 35005 ] {deca7b81-89a9-4a00-afd4-f9bde73935d7} TCPHandler: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/6dc/6dc07280-8d80-40fc-b0c3-dd8c77c18eac/all_1_2_1/data.bin: , errno: 2, strerror: No such file or directory: (while reading from part /var/lib/clickhouse/store/6dc/6dc07280-8d80-40fc-b0c3-dd8c77c18eac/all_1_2_1/ in table test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x00000000201471ef 4. ./contrib/llvm-project/libcxx/include/optional:344: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000020146945 5. ./build_docker/./src/IO/OpenedFile.cpp:40: DB::OpenedFile::getFD() const @ 0x000000003072b776 6. ./src/IO/AsynchronousReadBufferFromFile.h:0: DB::AsynchronousReadBufferFromFileWithDescriptorsCache::AsynchronousReadBufferFromFileWithDescriptorsCache(DB::IAsynchronousReader&, Priority, String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000003071c8a2 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x0000000030714fc3 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x0000000030714131 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000032eabf9d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000393a8e35 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:80: std::unique_ptr> std::__function::__policy_invoker> ()>::__call_impl> ()>>(std::__function::__policy_storage const*) @ 0x0000000039cd86b0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::CachedCompressedReadBuffer::initInput() @ 0x0000000039cda263 13. ./src/Compression/CachedCompressedReadBuffer.h:65: non-virtual thunk to DB::CachedCompressedReadBuffer::setReadUntilPosition(unsigned long) @ 0x0000000039ce0403 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:0: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039cd3424 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cc90ac 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c95352 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb8b36 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb1273 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf55eb4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 2025.06.18 11:18:00.291949 [ 2606 ] {} test_oxv821gc.rmt1 (6dc07280-8d80-40fc-b0c3-dd8c77c18eac): Directory /var/lib/clickhouse/store/6dc/6dc07280-8d80-40fc-b0c3-dd8c77c18eac/all_1_2_1 (part to remove) doesn't exist or one of nested files has gone. Most likely this is due to manual removing. This should be discouraged. Ignoring. 2025.06.18 11:18:03.894810 [ 35666 ] {30c680ea-67ad-49ad-92d6-1165ae40af7b} executeQuery: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 7. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 8. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:03.897253 [ 35666 ] {30c680ea-67ad-49ad-92d6-1165ae40af7b} TCPHandler: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 7. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 8. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:03.928558 [ 35666 ] {f61606fe-caa1-4c7e-8d8f-70d800ecd4a8} executeQuery: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 7. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 8. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:03.930956 [ 35666 ] {f61606fe-caa1-4c7e-8d8f-70d800ecd4a8} TCPHandler: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 7. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 8. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:04.628210 [ 35666 ] {6f5e03a6-e9f4-4b00-a696-a391ebaea2ab} executeQuery: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 > 1': While processing 1 > 1. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 > 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:151: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003572fd1c 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 8. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 9. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:04.630599 [ 35666 ] {6f5e03a6-e9f4-4b00-a696-a391ebaea2ab} TCPHandler: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 > 1': While processing 1 > 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:151: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003572fd1c 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 8. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 9. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.269115 [ 35666 ] {465a1358-804f-4256-93e6-dc654ece158e} executeQuery: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.271037 [ 35666 ] {465a1358-804f-4256-93e6-dc654ece158e} TCPHandler: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.291963 [ 35666 ] {bc58323b-00f7-496a-ad59-a3bc3a497f5e} executeQuery: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.294522 [ 35666 ] {bc58323b-00f7-496a-ad59-a3bc3a497f5e} TCPHandler: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.315378 [ 35666 ] {f802dc11-786d-4928-aade-20c8c2a6e19a} executeQuery: Code: 403. DB::Exception: Illegal expression 'NULL' in JOIN ON section: While processing NULL. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.317310 [ 35666 ] {f802dc11-786d-4928-aade-20c8c2a6e19a} TCPHandler: Code: 403. DB::Exception: Illegal expression 'NULL' in JOIN ON section: While processing NULL. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:77: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356623e2 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 6. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.957746 [ 35666 ] {06e51c6b-111c-4c0c-9539-a871a9b71f23} executeQuery: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 != 1': While processing 1 != 1. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 != 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:151: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003572fd1c 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:05.959749 [ 35666 ] {06e51c6b-111c-4c0c-9539-a871a9b71f23} TCPHandler: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 != 1': While processing 1 != 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:151: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003572fd1c 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:06.622438 [ 35632 ] {3b652100-2611-4809-b6f7-e37b4976f079} executeQuery: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44844) (comment: 02125_dict_get_type_nullable_fix.sql) (in query: SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970fa3c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:06.624507 [ 35632 ] {3b652100-2611-4809-b6f7-e37b4976f079} TCPHandler: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970fa3c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:06.656264 [ 35666 ] {d5b6f869-e893-422b-952e-34289b05ab37} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: -- Here is another error code because equality is handled differently in CollectJoinOnKeysVisitor. -- We can change the error code, but it will become inconsistent for other cases -- where we actually expect AMBIGUOUS_COLUMN_NAME instead of INVALID_JOIN_ON_EXPRESSION/INCOMPATIBLE_TYPE_OF_JOIN. -- These checks are more reliable after switching to a new analyzer, they return INCOMPATIBLE_TYPE_OF_JOIN consistent with cases above SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:115: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000357300db 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 8. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 9. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:06.658963 [ 35666 ] {d5b6f869-e893-422b-952e-34289b05ab37} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:115: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000357300db 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x0000000035662795 8. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000356627a0 9. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faff 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.251278 [ 35666 ] {e8ef6274-3f57-42f8-9ac5-9fa374df64e0} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:115: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000357300db 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.253802 [ 35666 ] {e8ef6274-3f57-42f8-9ac5-9fa374df64e0} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:115: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000357300db 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.276454 [ 35666 ] {0880a33b-4278-44d7-9130-f75e45f1c135} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 2' in JOIN ON section: While processing 1 = 2. (AMBIGUOUS_COLUMN_NAME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:115: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000357300db 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.278501 [ 35666 ] {0880a33b-4278-44d7-9130-f75e45f1c135} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 2' in JOIN ON section: While processing 1 = 2. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:115: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000357300db 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000356621c8 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000035661e75 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003562faec 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf3d50 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.499877 [ 1534 ] {b76e3a2d-d660-4382-8b77-3001a1279c54} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [k]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44862) (comment: 00118_storage_join.sql) (in query: SELECT k, js1.s, t2.s FROM (SELECT number AS k, number AS s FROM system.numbers LIMIT 10) js1 ANY LEFT JOIN t2 ON js1.k == t2.k OR js1.s == t2.k ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.502668 [ 1534 ] {b76e3a2d-d660-4382-8b77-3001a1279c54} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [k]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.861966 [ 35666 ] {03462ae4-833c-4b27-babf-9f7114b8a5ca} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000038404a97 4. ./build_docker/./src/Storages/StorageJoin.cpp:279: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fcc6d 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:07.864504 [ 35666 ] {03462ae4-833c-4b27-babf-9f7114b8a5ca} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000038404a97 4. ./build_docker/./src/Storages/StorageJoin.cpp:279: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fcc6d 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.010701 [ 35659 ] {21e6f622-0ca8-40c3-b344-aeed7f3d192e} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, UInt8) to AggregateFunction(sum, Int32) is not supported: while converting source column pv to destination column pv. (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44902) (comment: 01880_materialized_view_to_table_type_check.sql) (in query: CREATE MATERIALIZED VIEW test_mv to test(`id` Int32, `pv` AggregateFunction(sum, Int32)) as SELECT id, sumState(1) as pv from test_input group by id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x00000000087216d8 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086cb904 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000086c4c11 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321a587 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:286: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000003321d97d 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033264b0e 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bc48d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.012872 [ 35659 ] {21e6f622-0ca8-40c3-b344-aeed7f3d192e} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, UInt8) to AggregateFunction(sum, Int32) is not supported: while converting source column pv to destination column pv. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x00000000087216d8 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086cb904 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000086c4c11 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321a587 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:286: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000003321d97d 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033264b0e 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bc48d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.451827 [ 35666 ] {2b33ca83-0450-4392-8634-b1a7d6717250} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.454151 [ 35666 ] {2b33ca83-0450-4392-8634-b1a7d6717250} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.484169 [ 35666 ] {9d34ae27-98b3-470a-b387-21a7cd0b7cb6} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key2, key3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.486334 [ 35666 ] {9d34ae27-98b3-470a-b387-21a7cd0b7cb6} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.514308 [ 35666 ] {bab28fad-f2c9-4416-a4ed-a1d72bca6e37} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.516483 [ 35666 ] {bab28fad-f2c9-4416-a4ed-a1d72bca6e37} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.544424 [ 35666 ] {3427920c-d8c5-4cd0-91fc-8e75da5dc901} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.546462 [ 35666 ] {3427920c-d8c5-4cd0-91fc-8e75da5dc901} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.577438 [ 35666 ] {1524a631-9d6b-4764-8b0b-b5c2a7fd81e0} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000038404a97 4. ./build_docker/./src/Storages/StorageJoin.cpp:279: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fcc6d 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.579701 [ 35666 ] {1524a631-9d6b-4764-8b0b-b5c2a7fd81e0} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000038404a97 4. ./build_docker/./src/Storages/StorageJoin.cpp:279: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fcc6d 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.619085 [ 35666 ] {6199da5e-4444-4123-b92a-1bafe4089c3b} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.key3 AND t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:08.621864 [ 35666 ] {6199da5e-4444-4123-b92a-1bafe4089c3b} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000033a78dca 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000033a7633e 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa0427 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.304748 [ 35666 ] {fa0b494e-b1b2-439c-baf3-6286157e917d} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '1_UInt8' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v9::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000034de2a0d 4. ./build_docker/./src/Planner/PlannerJoins.cpp:878: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb0fa 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.306809 [ 35666 ] {fa0b494e-b1b2-439c-baf3-6286157e917d} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '1_UInt8' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v9::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000034de2a0d 4. ./build_docker/./src/Planner/PlannerJoins.cpp:878: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb0fa 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.350777 [ 35666 ] {1bf1839b-ec43-4c33-85a8-42c73b622632} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.352964 [ 35666 ] {1bf1839b-ec43-4c33-85a8-42c73b622632} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.399642 [ 35666 ] {3e700b78-b883-40d7-901d-8fe8622bc579} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 > 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.401821 [ 35666 ] {3e700b78-b883-40d7-901d-8fe8622bc579} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.468788 [ 35666 ] {73eb9d06-15c2-4d58-92c4-93cb52b33e29} executeQuery: Code: 264. DB::Exception: Table 'test_nfvwm9o1.tj (23adbf9c-c663-406d-b7f0-504f98ea3e1e)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd525 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.470731 [ 35666 ] {73eb9d06-15c2-4d58-92c4-93cb52b33e29} TCPHandler: Code: 264. DB::Exception: Table 'test_nfvwm9o1.tj (23adbf9c-c663-406d-b7f0-504f98ea3e1e)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd525 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.501834 [ 35666 ] {2da53373-56be-4e4e-9b8a-e30c887141dd} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.519823 [ 35666 ] {2da53373-56be-4e4e-9b8a-e30c887141dd} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.553562 [ 35666 ] {814df8a2-db51-40c3-918f-bb359cbc2021} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.555517 [ 35666 ] {814df8a2-db51-40c3-918f-bb359cbc2021} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.589215 [ 35666 ] {5bcc4dda-3ed3-450e-b7ed-ebc607c7b13d} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 != 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.591228 [ 35666 ] {5bcc4dda-3ed3-450e-b7ed-ebc607c7b13d} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.641420 [ 35666 ] {f76d560a-282f-49f6-a173-8bd11e00f973} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '_CAST(1_UInt8, 'UInt8'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: -- Here is another error code because equality is handled differently in CollectJoinOnKeysVisitor. -- We can change the error code, but it will become inconsistent for other cases -- where we actually expect AMBIGUOUS_COLUMN_NAME instead of INVALID_JOIN_ON_EXPRESSION/INCOMPATIBLE_TYPE_OF_JOIN. -- These checks are more reliable after switching to a new analyzer, they return INCOMPATIBLE_TYPE_OF_JOIN consistent with cases above SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v9::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000034de2a0d 4. ./build_docker/./src/Planner/PlannerJoins.cpp:878: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb0fa 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.643519 [ 35666 ] {f76d560a-282f-49f6-a173-8bd11e00f973} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '_CAST(1_UInt8, 'UInt8'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v9::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000034de2a0d 4. ./build_docker/./src/Planner/PlannerJoins.cpp:878: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb0fa 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.674345 [ 35666 ] {78ef9b90-2ab9-4d75-8568-917861130b0c} executeQuery: Code: 264. DB::Exception: Table 'test_nfvwm9o1.tj (23adbf9c-c663-406d-b7f0-504f98ea3e1e)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd525 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.676193 [ 35666 ] {78ef9b90-2ab9-4d75-8568-917861130b0c} TCPHandler: Code: 264. DB::Exception: Table 'test_nfvwm9o1.tj (23adbf9c-c663-406d-b7f0-504f98ea3e1e)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd525 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.703137 [ 35666 ] {077ed317-8a77-493a-affb-e9c2ae02cf92} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.704955 [ 35666 ] {077ed317-8a77-493a-affb-e9c2ae02cf92} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key3, key2, key1]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Storages/StorageJoin.cpp:245: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd76d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.730193 [ 35666 ] {22f802fa-be20-4ef6-b515-d5d0e2887ed8} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.732090 [ 35666 ] {22f802fa-be20-4ef6-b515-d5d0e2887ed8} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.760008 [ 35666 ] {1a1ff7df-13cb-447f-9ccd-ea4d25b65c50} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:10.761921 [ 35666 ] {1a1ff7df-13cb-447f-9ccd-ea4d25b65c50} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.198196 [ 35666 ] {18f9653b-2367-46ae-9fcd-e4b797233279} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key2, key3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.200139 [ 35666 ] {18f9653b-2367-46ae-9fcd-e4b797233279} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.238425 [ 35666 ] {25695089-ea09-476f-88c9-3c303dc89e5d} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.240647 [ 35666 ] {25695089-ea09-476f-88c9-3c303dc89e5d} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.279471 [ 35666 ] {4c0f0ff9-738a-4b3a-a42b-5198848da2aa} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.281500 [ 35666 ] {4c0f0ff9-738a-4b3a-a42b-5198848da2aa} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.370705 [ 35671 ] {53ae5b9d-ee68-4b59-b244-8106bccf51b4} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45094) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n') settings input_format_tsv_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b69bf95 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:11.373164 [ 35671 ] {53ae5b9d-ee68-4b59-b244-8106bccf51b4} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b69bf95 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:11.620207 [ 35671 ] {edf6e3ff-f7b8-4130-8a9c-0df5ae24eb16} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45094) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n1\t2\n') settings input_format_tsv_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b69bf95 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:11.622161 [ 35671 ] {edf6e3ff-f7b8-4130-8a9c-0df5ae24eb16} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b69bf95 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:11.766299 [ 35666 ] {8c611386-ee18-40d4-afa0-07f7494792e8} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000038404a97 4. ./build_docker/./src/Storages/StorageJoin.cpp:279: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fcc6d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.768469 [ 35666 ] {8c611386-ee18-40d4-afa0-07f7494792e8} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000038404a97 4. ./build_docker/./src/Storages/StorageJoin.cpp:279: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fcc6d 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.826673 [ 35666 ] {300d48e7-86c3-4ae1-8faa-752b8c4f0701} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44746) (comment: 02498_storage_join_key_positions.gen.sql) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.key3 AND t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:11.828920 [ 35666 ] {300d48e7-86c3-4ae1-8faa-752b8c4f0701} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001ff3af4d 4. ./build_docker/./src/Storages/StorageJoin.cpp:255: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fd2e1 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd6ecc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:12.244342 [ 35671 ] {08a9d5fa-fabd-4821-9fb8-efdbd55e75d3} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45094) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n') settings input_format_csv_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:12.246934 [ 35671 ] {08a9d5fa-fabd-4821-9fb8-efdbd55e75d3} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:12.322546 [ 35671 ] {a6d607f1-eb6e-4898-b528-6f3635e466c7} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45094) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n1,2\n') settings input_format_csv_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:12.324516 [ 35671 ] {a6d607f1-eb6e-4898-b528-6f3635e466c7} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:18:12.848053 [ 35636 ] {06cba3d0-9afa-4f3e-b671-e24936d47462} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.849817 [ 35636 ] {06cba3d0-9afa-4f3e-b671-e24936d47462} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.874069 [ 35636 ] {a8ebab8d-dafb-4fdc-84f7-560985ffccf3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(-1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.875702 [ 35636 ] {a8ebab8d-dafb-4fdc-84f7-560985ffccf3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.897448 [ 35636 ] {997378cc-9ec9-4745-a999-b5b7624bb322} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.898986 [ 35636 ] {997378cc-9ec9-4745-a999-b5b7624bb322} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.921500 [ 35636 ] {00ccd34c-50c4-46a8-aede-d7860c642deb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(-1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.923461 [ 35636 ] {00ccd34c-50c4-46a8-aede-d7860c642deb} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.926485 [ 35671 ] {ca7ab431-e070-4c8a-9d1d-341ca152f867} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45094) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./build_docker/./src/IO/ReadHelpers.cpp:103: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000020190fd0 5. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:126: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b1f98ba 6. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 18. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:18:12.928865 [ 35671 ] {ca7ab431-e070-4c8a-9d1d-341ca152f867} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./build_docker/./src/IO/ReadHelpers.cpp:103: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000020190fd0 5. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:126: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b1f98ba 6. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 18. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:18:12.945991 [ 35636 ] {bfd0e040-1c69-4105-bbfc-a81633ac688f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.947663 [ 35636 ] {bfd0e040-1c69-4105-bbfc-a81633ac688f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.970741 [ 35636 ] {45178f42-8ed2-4352-bf45-37924c648508} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(-1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.972353 [ 35636 ] {45178f42-8ed2-4352-bf45-37924c648508} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.995238 [ 35636 ] {b5f8ab7c-371e-475d-82af-f3d43dece867} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:12.996936 [ 35636 ] {b5f8ab7c-371e-475d-82af-f3d43dece867} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:13.000079 [ 35671 ] {a899b325-7024-4168-8189-8920b8c9b0db} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45094) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./build_docker/./src/IO/ReadHelpers.cpp:103: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000020190fd0 5. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:126: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b1f98ba 6. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 18. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:18:13.002047 [ 35671 ] {a899b325-7024-4168-8189-8920b8c9b0db} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./build_docker/./src/IO/ReadHelpers.cpp:103: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000020190fd0 5. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:126: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b1f98ba 6. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febf9f5 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 18. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:18:13.025963 [ 35636 ] {15234ffa-04cf-4102-b5e7-89ef1ec09095} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(cast(-1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:13.028038 [ 35636 ] {15234ffa-04cf-4102-b5e7-89ef1ec09095} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:13.222802 [ 36000 ] {ddc94576-892d-45de-993b-e5101d94fce2} executeQuery: Code: 36. DB::Exception: Argument 'ttl' must be a literal, get Identifier_k (value: k). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33350) (comment: 02811_invalid_embedded_rocksdb_create.sql) (in query: CREATE TABLE dict (`k` String, `v` String) ENGINE = EmbeddedRocksDB(k) PRIMARY KEY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: unsigned long DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000038d2840d 5. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c505b4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:13.224758 [ 36000 ] {ddc94576-892d-45de-993b-e5101d94fce2} TCPHandler: Code: 36. DB::Exception: Argument 'ttl' must be a literal, get Identifier_k (value: k). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: unsigned long DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000038d2840d 5. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c505b4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:13.379829 [ 31332 ] {7d127556-aeac-4b6c-84ff-a19e986828ee} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 579205132326352334, k: 1, error: 1: In scope SELECT h3HexRing(579205132326352334, toUInt16(1)) AS hexRing. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33338) (comment: 02293_h3_hex_ring.sql) (in query: SELECT h3HexRing(579205132326352334, toUInt16(1)) as hexRing;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x0000000012370a57 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001236f2e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:13.381789 [ 31332 ] {7d127556-aeac-4b6c-84ff-a19e986828ee} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 579205132326352334, k: 1, error: 1: In scope SELECT h3HexRing(579205132326352334, toUInt16(1)) AS hexRing. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x0000000012370a57 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001236f2e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:14.142948 [ 31332 ] {ba7c8ebe-5fe6-4851-85e2-e765f4fbd8ba} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3HexRing. Must be UInt16: In scope SELECT h3HexRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33338) (comment: 02293_h3_hex_ring.sql) (in query: SELECT h3HexRing(581276613233082367, -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000fe6ecd7 4. DB::(anonymous namespace)::FunctionH3HexRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001237065f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:14.144674 [ 31332 ] {ba7c8ebe-5fe6-4851-85e2-e765f4fbd8ba} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3HexRing. Must be UInt16: In scope SELECT h3HexRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000fe6ecd7 4. DB::(anonymous namespace)::FunctionH3HexRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001237065f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:14.329210 [ 35636 ] {24ed9ae4-8e35-4bf0-9b41-75f30de0190f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32('1980', '10', '20');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.331115 [ 35636 ] {24ed9ae4-8e35-4bf0-9b41-75f30de0190f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.352721 [ 35636 ] {2941acbc-a282-49da-9812-2f10abaa0b56} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32('-1980', 3, 17);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.355597 [ 35636 ] {2941acbc-a282-49da-9812-2f10abaa0b56} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.377843 [ 35636 ] {29427946-3945-4c09-809f-29bfd949c28b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32('aa', 3, 24);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.379673 [ 35636 ] {29427946-3945-4c09-809f-29bfd949c28b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.401561 [ 35636 ] {2df16947-2f09-4d58-957e-2ac7b3ec5505} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(1994, 'aa', 24);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.403285 [ 35636 ] {2df16947-2f09-4d58-957e-2ac7b3ec5505} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.424858 [ 35636 ] {acc97f9f-bda9-482b-855f-f25ee8f25692} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(1984, 3, 'aa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.426612 [ 35636 ] {acc97f9f-bda9-482b-855f-f25ee8f25692} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f99617 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:18:14.928482 [ 31332 ] {c668fa72-2d27-4cef-83c2-0237c2898ab6} executeQuery: Code: 12. DB::Exception: Too large 'k' argument for h3HexRing function, maximum 10000: In scope SELECT h3HexRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33338) (comment: 02293_h3_hex_ring.sql) (in query: SELECT h3HexRing(581276613233082367, toUInt16(-1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001237094d 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001236f164 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:14.930237 [ 31332 ] {c668fa72-2d27-4cef-83c2-0237c2898ab6} TCPHandler: Code: 12. DB::Exception: Too large 'k' argument for h3HexRing function, maximum 10000: In scope SELECT h3HexRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001237094d 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001236f164 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:15.628644 [ 35636 ] {c7f5f285-7f07-4bda-b5f2-960a30145b51} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate32(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(1980);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:15.631379 [ 35636 ] {c7f5f285-7f07-4bda-b5f2-960a30145b51} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate32(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:15.653324 [ 35636 ] {325dcd7f-5581-4225-908c-ed05c29fcb70} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate32(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45108) (comment: 02243_make_date32.sql) (in query: select makeDate32(1980, 1, 1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:15.655119 [ 35636 ] {325dcd7f-5581-4225-908c-ed05c29fcb70} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate32(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:15.812196 [ 35047 ] {678991a0-c4e2-49b9-a5a6-17e38dcd6cee} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33432) (comment: 02317_functions_with_nothing.sql) (in query: SELECT JSONExtractKeysAndValuesRaw(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.814214 [ 35047 ] {678991a0-c4e2-49b9-a5a6-17e38dcd6cee} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.841636 [ 35047 ] {712fab76-0def-498b-9c05-0383c6646085} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33432) (comment: 02317_functions_with_nothing.sql) (in query: SELECT JSONHas(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.843957 [ 35047 ] {712fab76-0def-498b-9c05-0383c6646085} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.868091 [ 35047 ] {07d314ad-5542-41ca-95fd-27c2ea645925} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33432) (comment: 02317_functions_with_nothing.sql) (in query: SELECT isValidJSON(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.869811 [ 35047 ] {07d314ad-5542-41ca-95fd-27c2ea645925} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.895138 [ 35047 ] {bbfd56c2-1c36-4f78-bb71-126ab24d9c1a} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33432) (comment: 02317_functions_with_nothing.sql) (in query: SELECT concat(arrayJoin([]), arrayJoin([NULL, '']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.897010 [ 35047 ] {bbfd56c2-1c36-4f78-bb71-126ab24d9c1a} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.924035 [ 35047 ] {8faf3821-4ea9-486a-b332-1781a49bc92e} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33432) (comment: 02317_functions_with_nothing.sql) (in query: SELECT plus(arrayJoin([]), arrayJoin([NULL, 1]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.925823 [ 35047 ] {8faf3821-4ea9-486a-b332-1781a49bc92e} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.950883 [ 35047 ] {d1901936-c954-40a3-bdd0-b9495c834730} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33432) (comment: 02317_functions_with_nothing.sql) (in query: SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:15.952709 [ 35047 ] {d1901936-c954-40a3-bdd0-b9495c834730} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5608: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033430a37 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:16.913027 [ 35632 ] {1c9266bf-8f1b-4011-8642-df973b39fc82} executeQuery: Code: 43. DB::Exception: Function array can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33450) (comment: 03207_composite_expressions_lambda_consistent_formatting.sql) (in query: SELECT [1, (x -> 1)];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::IFunction::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000837acae 4. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x00000000083cdd71 5. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000b60a03b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349af58 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:16.915307 [ 35632 ] {1c9266bf-8f1b-4011-8642-df973b39fc82} TCPHandler: Code: 43. DB::Exception: Function array can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::IFunction::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000837acae 4. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x00000000083cdd71 5. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000b60a03b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349af58 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:16.938950 [ 35632 ] {d6a732b9-43d4-47d7-bac6-33c1899b4794} executeQuery: Code: 43. DB::Exception: Function tuple can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33450) (comment: 03207_composite_expressions_lambda_consistent_formatting.sql) (in query: SELECT (1, (x -> 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::IFunction::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000837acae 4. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x00000000083cdd71 5. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000b60a03b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349af58 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:16.940689 [ 35632 ] {d6a732b9-43d4-47d7-bac6-33c1899b4794} TCPHandler: Code: 43. DB::Exception: Function tuple can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::IFunction::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000837acae 4. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x00000000083cdd71 5. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000b60a03b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349af58 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:16.964791 [ 35632 ] {9ca8ea25-480b-4f69-9049-9b1305da4f22} executeQuery: Code: 43. DB::Exception: Function map can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33450) (comment: 03207_composite_expressions_lambda_consistent_formatting.sql) (in query: SELECT map(1, (x -> 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::IFunction::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000837acae 4. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x00000000083cdd71 5. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000b60a03b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349af58 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:16.966565 [ 35632 ] {9ca8ea25-480b-4f69-9049-9b1305da4f22} TCPHandler: Code: 43. DB::Exception: Function map can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::IFunction::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000837acae 4. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x00000000083cdd71 5. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000b60a03b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349af58 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:17.697245 [ 35632 ] {a0d13fa6-9142-41ba-91cb-64eb7bdd01d6} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'x' in scope SELECT [1, (x -> 1)]. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33450) (comment: 03207_composite_expressions_lambda_consistent_formatting.sql) (in query: SELECT [1, lambda(x, 1)];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:17.699111 [ 35632 ] {a0d13fa6-9142-41ba-91cb-64eb7bdd01d6} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'x' in scope SELECT [1, (x -> 1)]. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:17.723259 [ 35632 ] {c656b5f7-bf92-4570-9f35-785180f9cb0c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'x' in scope SELECT (1, (x -> 1)). (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33450) (comment: 03207_composite_expressions_lambda_consistent_formatting.sql) (in query: SELECT (1, lambda(x, 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:17.725044 [ 35632 ] {c656b5f7-bf92-4570-9f35-785180f9cb0c} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'x' in scope SELECT (1, (x -> 1)). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:17.747489 [ 35632 ] {6de92d17-2408-43c5-9a4d-be3b7a7818d7} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'x' in scope SELECT map(1, (x -> 1)). (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33450) (comment: 03207_composite_expressions_lambda_consistent_formatting.sql) (in query: SELECT map(1, lambda(x, 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:17.749371 [ 35632 ] {6de92d17-2408-43c5-9a4d-be3b7a7818d7} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'x' in scope SELECT map(1, (x -> 1)). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:17.824530 [ 1597 ] {238089c5-cbaa-4067-96cc-48398c5ff039} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'LowCardinality(Nullable(String))'), 'String'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33492) (comment: 00974_low_cardinality_cast.sql) (in query: SELECT CAST(CAST(Null AS LowCardinality(Nullable(String))) AS String);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000091c5183 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:17.826793 [ 1597 ] {238089c5-cbaa-4067-96cc-48398c5ff039} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'LowCardinality(Nullable(String))'), 'String'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000091c5183 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:18.016171 [ 36047 ] {acc42842-4511-4d34-a163-ffb7873b5588} executeQuery: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33516) (comment: 01548_uncomparable_columns_in_keys.sql) (in query: CREATE TABLE foo (`id` UInt64, `key` AggregateFunction(max, UInt64)) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 63481, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 16466846, compact_parts_max_granules_to_buffer = 240, compact_parts_merge_max_bytes_to_prefetch_part = 2455771, merge_max_block_size = 17669, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 8336261440, vertical_merge_algorithm_min_rows_to_activate = 510273, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 14246963, concurrent_part_removal_threshold = 55, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 93977, primary_key_compress_block_size = 97552), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038198979 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2ad27f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:18.018545 [ 36047 ] {acc42842-4511-4d34-a163-ffb7873b5588} TCPHandler: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038198979 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2ad27f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:18.571538 [ 36047 ] {e0bfaf7e-51ee-4377-adc3-aed7f36716bd} executeQuery: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33516) (comment: 01548_uncomparable_columns_in_keys.sql) (in query: CREATE TABLE foo (`id` UInt64, `key` AggregateFunction(max, UInt64)) ENGINE = MergeTree PARTITION BY key SETTINGS index_granularity = 63481, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 16466846, compact_parts_max_granules_to_buffer = 240, compact_parts_merge_max_bytes_to_prefetch_part = 2455771, merge_max_block_size = 17669, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 8336261440, vertical_merge_algorithm_min_rows_to_activate = 510273, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 14246963, concurrent_part_removal_threshold = 55, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 93977, primary_key_compress_block_size = 97552), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038198979 5. ./contrib/llvm-project/libcxx/include/optional:260: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038199409 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:644: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aa83f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:18.574399 [ 36047 ] {e0bfaf7e-51ee-4377-adc3-aed7f36716bd} TCPHandler: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038198979 5. ./contrib/llvm-project/libcxx/include/optional:260: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038199409 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:644: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aa83f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:18.618891 [ 36047 ] {f3836197-6e8b-4c4b-887a-63d4d9c3d67c} executeQuery: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33516) (comment: 01548_uncomparable_columns_in_keys.sql) (in query: CREATE TABLE foo (`id` UInt64, `key` AggregateFunction(max, UInt64)) ENGINE = MergeTree ORDER BY key SAMPLE BY key SETTINGS index_granularity = 63481, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 16466846, compact_parts_max_granules_to_buffer = 240, compact_parts_merge_max_bytes_to_prefetch_part = 2455771, merge_max_block_size = 17669, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 8336261440, vertical_merge_algorithm_min_rows_to_activate = 510273, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 14246963, concurrent_part_removal_threshold = 55, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 93977, primary_key_compress_block_size = 97552), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038198979 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2ad27f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:18.621050 [ 36047 ] {f3836197-6e8b-4c4b-887a-63d4d9c3d67c} TCPHandler: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038198979 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2ad27f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:18.689460 [ 1597 ] {7cdeca63-a076-4dc2-8c09-0f466748edb7} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'String'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33492) (comment: 00974_low_cardinality_cast.sql) (in query: SELECT CAST(CAST(Null AS Nullable(String)) AS String);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000091c26b2 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:18.691670 [ 1597 ] {7cdeca63-a076-4dc2-8c09-0f466748edb7} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'String'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000091c26b2 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:18:19.073631 [ 612 ] {21de2039-4b17-476a-8c0d-183025627a48} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON arrayExists(x -> (x = 1), t.arr). (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33538) (comment: 02834_array_exists_segfault.sql) (in query: WITH subquery AS (SELECT []) SELECT t.* FROM 02834_t AS t JOIN subquery ON arrayExists(x -> x = 1, t.arr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:19.076874 [ 612 ] {21de2039-4b17-476a-8c0d-183025627a48} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON arrayExists(x -> (x = 1), t.arr). (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.186921 [ 35669 ] {23b5fe90-39cb-4ed6-908e-278ed6d88927} executeQuery: Code: 16. DB::Exception: There is no column with name `alias` in table test_2sztdleq.full_duplicates (59283dc7-8bc6-4d8c-a1eb-790db63a5721). There are columns: pk, sk, val, partition_key, mat. (NO_SUCH_COLUMN_IN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33588) (comment: 01581_deduplicate_by_columns_local.sql) (in query: -- ERROR cases OPTIMIZE TABLE full_duplicates DEDUPLICATE BY pk, sk, val, mat, alias;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:281: DB::StorageSnapshot::check(std::vector> const&) const @ 0x0000000038c402c9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be99f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.188727 [ 35669 ] {23b5fe90-39cb-4ed6-908e-278ed6d88927} TCPHandler: Code: 16. DB::Exception: There is no column with name `alias` in table test_2sztdleq.full_duplicates (59283dc7-8bc6-4d8c-a1eb-790db63a5721). There are columns: pk, sk, val, partition_key, mat. (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:281: DB::StorageSnapshot::check(std::vector> const&) const @ 0x0000000038c402c9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be99f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.518777 [ 35669 ] {1d1b1117-654b-4baa-b704-befe9a5402d1} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val']. (THERE_IS_NO_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33588) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY sk, val;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.520386 [ 35669 ] {1d1b1117-654b-4baa-b704-befe9a5402d1} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.780627 [ 35674 ] {d5bc643c-d56d-4970-a060-d76564f61355} executeQuery: Code: 43. DB::Exception: Arguments of function nowInBlock should be String or FixedString: In scope SELECT nowInBlock(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33566) (comment: 02372_now_in_block.sql) (in query: SELECT nowInBlock(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad3dfd 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:20.782339 [ 35674 ] {d5bc643c-d56d-4970-a060-d76564f61355} TCPHandler: Code: 43. DB::Exception: Arguments of function nowInBlock should be String or FixedString: In scope SELECT nowInBlock(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad3dfd 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:20.874454 [ 35669 ] {47d348e3-a2dc-41f6-b0e6-9af0a460deff} executeQuery: Code: 51. DB::Exception: Empty list of columns queried. There are columns: pk, sk, val, partition_key, mat. (EMPTY_LIST_OF_COLUMNS_QUERIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33588) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(pk, sk, val, mat, alias, partition_key);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:265: DB::StorageSnapshot::check(std::vector> const&) const @ 0x0000000038c404e9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be99f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.876275 [ 35669 ] {47d348e3-a2dc-41f6-b0e6-9af0a460deff} TCPHandler: Code: 51. DB::Exception: Empty list of columns queried. There are columns: pk, sk, val, partition_key, mat. (EMPTY_LIST_OF_COLUMNS_QUERIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:265: DB::StorageSnapshot::check(std::vector> const&) const @ 0x0000000038c404e9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be99f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.890970 [ 35669 ] {59dec6a1-9775-4834-9db7-675dfa4e023b} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33588) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(pk);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.892450 [ 35669 ] {59dec6a1-9775-4834-9db7-675dfa4e023b} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.905429 [ 35669 ] {beb53259-cb8f-4df1-b0aa-af22da326308} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'sk' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33588) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(sk);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.906777 [ 35669 ] {beb53259-cb8f-4df1-b0aa-af22da326308} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'sk' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.919841 [ 35669 ] {115abed5-318f-4fd1-a15f-efb75d842334} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'partition_key' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'sk', 'val']. (THERE_IS_NO_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33588) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(partition_key);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:20.921283 [ 35669 ] {115abed5-318f-4fd1-a15f-efb75d842334} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'partition_key' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'sk', 'val']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000359c1acd 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359c0a8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:21.569970 [ 35674 ] {370bfc99-251f-4e95-bee3-1dbe09d0e55d} executeQuery: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock('UTC', 'UTC'). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33566) (comment: 02372_now_in_block.sql) (in query: SELECT nowInBlock('UTC', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad3c36 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:21.571772 [ 35674 ] {370bfc99-251f-4e95-bee3-1dbe09d0e55d} TCPHandler: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock('UTC', 'UTC'). (TOO_MANY_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad3c36 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.179910 [ 25481 ] {93e3b714-de45-4fbb-aaea-4f189ef4c225} ConnectionPoolWithFailover: There is no table `test_upeszk7u`.`local_01099_b` on server: 127.0.0.1:9000 2025.06.18 11:18:26.181641 [ 25508 ] {93e3b714-de45-4fbb-aaea-4f189ef4c225} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:26.182447 [ 25508 ] {93e3b714-de45-4fbb-aaea-4f189ef4c225} ConnectionPoolWithFailover: Connection failed at try â„–2, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:26.182906 [ 25508 ] {93e3b714-de45-4fbb-aaea-4f189ef4c225} ConnectionPoolWithFailover: Connection failed at try â„–3, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:26.190570 [ 25458 ] {93e3b714-de45-4fbb-aaea-4f189ef4c225} ConnectionPoolWithFailover: There is no table `test_upeszk7u`.`local_01099_b` on server: 127.0.0.2:9000 2025.06.18 11:18:26.629210 [ 35666 ] {93e3b714-de45-4fbb-aaea-4f189ef4c225} StorageDistributed (distributed_01099_b): Cannot flush: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_upeszk7u`.`local_01099_b` on server: 127.0.0.2:9000 : While sending /var/lib/clickhouse/store/f65/f65cd4d2-771c-4d03-970a-7813e0cd49b7/shard1_replica2/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d3ddca 3. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a8252df 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:229: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a81cdf3 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a81ddd2 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x00000000392c1034 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:379: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x00000000392b0637 8. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x00000000392afe8b 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000382b5d0e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303efa0c 11. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303ef7ed 12. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f1eee 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:26.655345 [ 16279 ] {fd87bcc9-2c23-4c80-a6fc-a69db79f0e2d} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64 = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.657313 [ 16279 ] {fd87bcc9-2c23-4c80-a6fc-a69db79f0e2d} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.690918 [ 16279 ] {bacf993c-8e21-412e-a20f-bd0fcaf9ab3f} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_tdigest = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.693007 [ 16279 ] {bacf993c-8e21-412e-a20f-bd0fcaf9ab3f} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.731889 [ 16279 ] {b30320b5-6090-44a8-aee9-b5a06b01ba99} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_count_min = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.733948 [ 16279 ] {b30320b5-6090-44a8-aee9-b5a06b01ba99} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.734964 [ 35661 ] {7cdd69a2-1022-4915-8756-b836b7140e75} executeQuery: Code: 137. DB::Exception: Unknown dictionary layout type: iptrie. (UNKNOWN_ELEMENT_IN_CONFIG) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49992) (comment: 01256_misspell_layout_name_podshumok.sql) (in query: CREATE DICTIONARY testip ( `network` String, `test_field` String ) PRIMARY KEY network SOURCE(FILE(PATH '/tmp/test.csv' FORMAT CSVWithNames)) LIFETIME(MIN 0 MAX 300) LAYOUT(IPTRIE());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:74: DB::DictionaryFactory::isComplex(String const&) const @ 0x00000000306af265 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328ca6e0 6. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824b42c 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:26.737575 [ 35661 ] {7cdd69a2-1022-4915-8756-b836b7140e75} TCPHandler: Code: 137. DB::Exception: Unknown dictionary layout type: iptrie. (UNKNOWN_ELEMENT_IN_CONFIG), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:74: DB::DictionaryFactory::isComplex(String const&) const @ 0x00000000306af265 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328ca6e0 6. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824b42c 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:26.774224 [ 16279 ] {bd31a1cc-bfe7-4178-90e2-ad72858f2a8c} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_uniq = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:26.776483 [ 16279 ] {bd31a1cc-bfe7-4178-90e2-ad72858f2a8c} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec454a0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfba8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:27.653912 [ 3205 ] {2af93931-615e-4a1a-aa5b-9def836e40e4} ConnectionPoolWithFailover: There is no table `test_upeszk7u`.`local_01099_b` on server: 127.0.0.2:9000 2025.06.18 11:18:27.654921 [ 2690 ] {2af93931-615e-4a1a-aa5b-9def836e40e4} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:27.655230 [ 2972 ] {2af93931-615e-4a1a-aa5b-9def836e40e4} ConnectionPoolWithFailover: There is no table `test_upeszk7u`.`local_01099_b` on server: 127.0.0.1:9000 2025.06.18 11:18:27.655377 [ 2690 ] {2af93931-615e-4a1a-aa5b-9def836e40e4} ConnectionPoolWithFailover: Connection failed at try â„–2, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:27.655826 [ 2690 ] {2af93931-615e-4a1a-aa5b-9def836e40e4} ConnectionPoolWithFailover: Connection failed at try â„–3, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:27.657065 [ 35666 ] {2af93931-615e-4a1a-aa5b-9def836e40e4} StorageDistributed (distributed_01099_b): Cannot flush: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_upeszk7u`.`local_01099_b` on server: 127.0.0.2:9000 : While sending /var/lib/clickhouse/store/fbe/fbed3ed7-e424-4583-930d-4ec54c743880/shard1_replica2/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d3ddca 3. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a8252df 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:229: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a81cdf3 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a81ddd2 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x00000000392c1034 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:379: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x00000000392b0637 8. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x00000000392afe8b 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000382b5d0e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303efa0c 11. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303ef7ed 12. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f1eee 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:27.991791 [ 36047 ] {3482e985-e520-4a33-8116-9a7a42f0f54e} executeQuery: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50028) (comment: 01089_alter_settings_old_format.sql) (in query: ALTER TABLE old_format_mt MODIFY SETTING enable_mixed_granularity_parts = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a0521 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:27.993614 [ 36047 ] {3482e985-e520-4a33-8116-9a7a42f0f54e} TCPHandler: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a0521 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:28.840704 [ 612 ] {0d8e315a-a0e3-4007-bf95-6542cd0a4bbd} executeQuery: Code: 115. DB::Exception: Setting min_block_size is unknown or not supported at column level, supported settings: max_compress_block_size, min_compress_block_size. (UNKNOWN_SETTING) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50002) (comment: 02870_per_column_settings.sql) (in query: -- Unsupported column-level settings are rejected CREATE TABLE tab ( id UInt64, long_string String SETTINGS (min_block_size = 81920, max_compress_block_size = 163840), ) ENGINE = MergeTree ORDER BY id SETTINGS min_bytes_for_wide_part = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception*, long>, std::__tree_const_iterator*, long>, char>>(int, FormatStringHelperImpl::type, std::type_identity*, long>, std::__tree_const_iterator*, long>, char>>::type>, String const&, fmt::v9::join_view*, long>, std::__tree_const_iterator*, long>, char>&&) @ 0x0000000039dda06d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:242: DB::MergeTreeColumnSettings::validate(DB::SettingsChanges const&) @ 0x0000000039d8091b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489bdd1 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:28.842850 [ 612 ] {0d8e315a-a0e3-4007-bf95-6542cd0a4bbd} TCPHandler: Code: 115. DB::Exception: Setting min_block_size is unknown or not supported at column level, supported settings: max_compress_block_size, min_compress_block_size. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception*, long>, std::__tree_const_iterator*, long>, char>>(int, FormatStringHelperImpl::type, std::type_identity*, long>, std::__tree_const_iterator*, long>, char>>::type>, String const&, fmt::v9::join_view*, long>, std::__tree_const_iterator*, long>, char>&&) @ 0x0000000039dda06d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:242: DB::MergeTreeColumnSettings::validate(DB::SettingsChanges const&) @ 0x0000000039d8091b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489bdd1 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:29.138919 [ 16279 ] {6be26716-6153-4464-be54-875ddfd03c95} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64 < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:29.141550 [ 16279 ] {6be26716-6153-4464-be54-875ddfd03c95} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:29.185659 [ 16279 ] {3f3d5200-6123-4310-be81-f3dbc995b066} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_tdigest < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:29.188080 [ 16279 ] {3f3d5200-6123-4310-be81-f3dbc995b066} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:29.231315 [ 16279 ] {8be252fa-55a5-46f7-8747-4d16296857b6} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_count_min < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:29.233950 [ 16279 ] {8be252fa-55a5-46f7-8747-4d16296857b6} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:29.277598 [ 16279 ] {23cae7ff-4dba-4849-b72b-598749a1066e} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_uniq < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:29.280069 [ 16279 ] {23cae7ff-4dba-4849-b72b-598749a1066e} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b4f260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b05b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:18:31.320680 [ 35666 ] {c99b585f-d16e-41b3-8142-82f688151b1b} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:33.821171 [ 36000 ] {37bae490-dab5-47dc-b3c2-e2cc3f7df7dd} executeQuery: Code: 153. DB::Exception: Cannot perform integer division on infinite or too large floating point numbers: while executing 'FUNCTION intDiv(__table1.number :: 2, nan_Float64 :: 1) -> intDiv(__table1.number, nan_Float64) Int64 : 0'. (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52600) (comment: 01683_intdiv_ubsan.sql) (in query: SELECT DISTINCT intDiv(number, nan) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000130558f5 5. void DB::impl_::BinaryOperation, long>::process<(DB::impl_::OpCase)2>(unsigned long const*, double const*, long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000130554c5 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000013621fe3 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x00000000135f7c5e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000135f5332 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001355d0bf 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001354dcd6 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000135487cb 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013544f9c 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:33.823941 [ 36000 ] {37bae490-dab5-47dc-b3c2-e2cc3f7df7dd} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division on infinite or too large floating point numbers: while executing 'FUNCTION intDiv(__table1.number :: 2, nan_Float64 :: 1) -> intDiv(__table1.number, nan_Float64) Int64 : 0'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000130558f5 5. void DB::impl_::BinaryOperation, long>::process<(DB::impl_::OpCase)2>(unsigned long const*, double const*, long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000130554c5 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000013621fe3 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x00000000135f7c5e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000135f5332 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001355d0bf 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001354dcd6 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000135487cb 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013544f9c 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:34.014382 [ 35005 ] {735a89dd-be1d-4eeb-b0ec-5f75eeed3124} executeQuery: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_index` to drop. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52674) (comment: 00953_indices_alter_exceptions.sh) (in query: ALTER TABLE test_drop_indices DROP INDEX test_index;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Storages/AlterCommands.cpp:692: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038086eeb 5. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:34.018936 [ 35005 ] {735a89dd-be1d-4eeb-b0ec-5f75eeed3124} TCPHandler: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_index` to drop. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Storages/AlterCommands.cpp:692: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038086eeb 5. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:34.881617 [ 35636 ] {598fd029-870b-4641-99ca-d1cb546ffed2} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52646) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000039be57ac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000039ad59ce 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:0: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x00000000399c5420 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399c21a5 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:28: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000003999fd7e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039976c7e 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:179: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399bcbbd 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039e1ec8f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool, bool, DB::WriteSettings>(std::shared_ptr&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool&&, bool&&, DB::WriteSettings&&) @ 0x0000000039f13d09 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efe699 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 16. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 17. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 23. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:34.884259 [ 35636 ] {598fd029-870b-4641-99ca-d1cb546ffed2} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000039be57ac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000039ad59ce 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:0: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x00000000399c5420 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399c21a5 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:28: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000003999fd7e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039976c7e 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:179: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399bcbbd 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039e1ec8f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool, bool, DB::WriteSettings>(std::shared_ptr&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool&&, bool&&, DB::WriteSettings&&) @ 0x0000000039f13d09 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efe699 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 16. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 17. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 23. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:34.989221 [ 35047 ] {b16afb84-1c02-4343-b09e-1bf2eaa91c6e} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52686) (comment: 01013_totals_without_aggregation.sql) (in query: SELECT 1 AS n WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587a91 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:34.991733 [ 35047 ] {b16afb84-1c02-4343-b09e-1bf2eaa91c6e} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587a91 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:35.005777 [ 35047 ] {83d316ed-fa0b-4210-91f5-1fe48f8cff50} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52686) (comment: 01013_totals_without_aggregation.sql) (in query: SELECT 1 AS n WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587a91 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:35.007425 [ 35047 ] {83d316ed-fa0b-4210-91f5-1fe48f8cff50} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587a91 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:35.026301 [ 35047 ] {99ab96ff-f288-47e3-ae0a-c886d8a74b39} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52686) (comment: 01013_totals_without_aggregation.sql) (in query: SELECT 1 AS n WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587a91 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:35.028214 [ 35047 ] {99ab96ff-f288-47e3-ae0a-c886d8a74b39} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587a91 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:35.247125 [ 35636 ] {d4660970-ad7c-43a5-adbe-76061362d314} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52646) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000039be57ac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000039ad59ce 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:0: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x00000000399c5420 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399c21a5 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:28: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000003999fd7e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039976c7e 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:179: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399bcbbd 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039e1ec8f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool, bool, DB::WriteSettings>(std::shared_ptr&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool&&, bool&&, DB::WriteSettings&&) @ 0x0000000039f13d09 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efe699 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 16. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 17. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 23. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:35.249602 [ 35636 ] {d4660970-ad7c-43a5-adbe-76061362d314} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000039be57ac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000039ad59ce 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:0: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x00000000399c5420 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399c21a5 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:28: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000003999fd7e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039976c7e 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:179: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399bcbbd 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039e1ec8f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool, bool, DB::WriteSettings>(std::shared_ptr&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool&&, bool&&, DB::WriteSettings&&) @ 0x0000000039f13d09 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efe699 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef594a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a39caf5 16. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 17. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 23. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:36.156746 [ 1534 ] {d65bc437-1d01-4b2f-ab77-69becd1e4332} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52714) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:36.162829 [ 1534 ] {d65bc437-1d01-4b2f-ab77-69becd1e4332} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:36.972031 [ 1597 ] {d13a7d91-0219-41bd-ba37-098e2aa0b95b} executeQuery: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52772) (comment: 02833_tuple_concat.sql) (in query: SELECT tupleConcat();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c9376eb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:36.974168 [ 1597 ] {d13a7d91-0219-41bd-ba37-098e2aa0b95b} TCPHandler: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c9376eb 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:36.982032 [ 35671 ] {095c9278-ba5b-46d4-89fc-51a10f418711} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52788) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:36.986691 [ 35671 ] {095c9278-ba5b-46d4-89fc-51a10f418711} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:37.793862 [ 1597 ] {68f39ee2-1380-4ada-b5e8-a217c41cca5e} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument 2 of function tupleConcat: In scope SELECT tupleConcat((1, 'y'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52772) (comment: 02833_tuple_concat.sql) (in query: SELECT tupleConcat((1, 'y'), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c9374f5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:37.795712 [ 1597 ] {68f39ee2-1380-4ada-b5e8-a217c41cca5e} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument 2 of function tupleConcat: In scope SELECT tupleConcat((1, 'y'), 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c9374f5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:18:37.811019 [ 35671 ] {26777ab1-e5fb-4916-8e43-2c38753880e9} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Array(UInt32).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52800) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Array(UInt32)')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:37.817425 [ 16279 ] {b0530be7-11d9-47b0-bf09-a92bb49aa70d} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE s = 7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ed462 4. ./contrib/llvm-project/libcxx/include/vector:1501: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fc4f5 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000ec4c592 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfe3a8 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 16. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 17. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 18. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 20. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:37.817436 [ 35671 ] {26777ab1-e5fb-4916-8e43-2c38753880e9} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Array(UInt32).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:37.819590 [ 16279 ] {b0530be7-11d9-47b0-bf09-a92bb49aa70d} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ed462 4. ./contrib/llvm-project/libcxx/include/vector:1501: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fc4f5 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000ec4c592 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfe3a8 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 16. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 17. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 18. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 20. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:37.857712 [ 16279 ] {28c6787f-5b76-4790-a1f6-a88fc5fac8b1} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49928) (comment: 02864_statistics_predicates.sql) (in query: -- SELECT count(*) FROM tab WHERE s_tdigest = 7; -- not supported SELECT count(*) FROM tab WHERE s_count_min = 7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ed462 4. ./contrib/llvm-project/libcxx/include/vector:1501: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fc4f5 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000ec4c592 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfe3a8 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 16. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 17. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 18. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 20. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:37.859900 [ 16279 ] {28c6787f-5b76-4790-a1f6-a88fc5fac8b1} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ed462 4. ./contrib/llvm-project/libcxx/include/vector:1501: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325fc4f5 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000ec4c592 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfe3a8 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80c028 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be0dc9c 16. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5a911 17. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d16a6e 18. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfec31 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 20. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:38.434841 [ 31332 ] {b0bd0ff8-8836-42af-98d2-3f372e073955} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52808) (comment: 01851_clear_column_referenced_by_mv.sql) (in query: ALTER TABLE `01851_merge_tree` DROP COLUMN n3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759811 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:38.436921 [ 31332 ] {b0bd0ff8-8836-42af-98d2-3f372e073955} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759811 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:38.480682 [ 31332 ] {f3023418-db74-461c-bb57-859902769db0} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52808) (comment: 01851_clear_column_referenced_by_mv.sql) (in query: ALTER TABLE `01851_merge_tree` DROP COLUMN n2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759811 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:38.482542 [ 31332 ] {f3023418-db74-461c-bb57-859902769db0} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759811 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:38.603512 [ 35666 ] {eaab2a5c-7e28-40a1-a1b3-51c95632386a} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52822) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Map(UInt64, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:38.608800 [ 35666 ] {eaab2a5c-7e28-40a1-a1b3-51c95632386a} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:264: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x000000003b28a6c7 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9ada 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:39.000037 [ 35675 ] {f31f88cc-a26b-49a3-b643-b4aeccb2ccb3} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 400.00 B, current bytes: 496.00 B: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52814) (comment: 01710_projection_with_mixed_pipeline.sql) (in query: select uniqHLL12(x) from t settings optimize_use_projections = 1, max_bytes_to_read=400, max_block_size=8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000032353e57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353a6d 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:39.005640 [ 35675 ] {f31f88cc-a26b-49a3-b643-b4aeccb2ccb3} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 400.00 B, current bytes: 496.00 B: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000032353e57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353a6d 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:41.019609 [ 31332 ] {16c50158-c747-4f0d-9b2e-9c7ac8b0fcc8} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52892) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:41.024426 [ 31332 ] {16c50158-c747-4f0d-9b2e-9c7ac8b0fcc8} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:41.193876 [ 35047 ] {8e068e63-d63f-4c2d-ac51-6f887f5d74fc} executeQuery: Code: 174. DB::Exception: Cyclic aliases for identifier 'val'. In scope SELECT val, val + 1 AS prev, val + prev AS val FROM (SELECT 1 AS val). (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52904) (comment: 02896_cyclic_aliases_crash.sql) (in query: SELECT val, val + 1 as prev, val + prev as val FROM ( SELECT 1 as val ) ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1114: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347463e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347312e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 12. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347312e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 18. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:18:41.196783 [ 35047 ] {8e068e63-d63f-4c2d-ac51-6f887f5d74fc} TCPHandler: Code: 174. DB::Exception: Cyclic aliases for identifier 'val'. In scope SELECT val, val + 1 AS prev, val + prev AS val FROM (SELECT 1 AS val). (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1114: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347463e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347312e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 12. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347312e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 18. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:18:41.975128 [ 35005 ] {26981748-fb6e-4c34-9001-2921f446db23} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60500) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:41.979928 [ 35005 ] {26981748-fb6e-4c34-9001-2921f446db23} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:42.868567 [ 36047 ] {7371bcd5-505f-405c-88a6-d5fcdfbb8caa} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60518) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Array(UInt64)')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:42.873606 [ 36047 ] {7371bcd5-505f-405c-88a6-d5fcdfbb8caa} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:43.729968 [ 1590 ] {6a176663-8b2b-4e29-96e3-deb88c1dce44} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60550) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Map(UInt64, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:43.736712 [ 1590 ] {6a176663-8b2b-4e29-96e3-deb88c1dce44} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:197: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x000000003b288441 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7511 6. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 16. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:46.327806 [ 35670 ] {ad12a8b3-29d2-4030-b7cb-3dc31f5184b5} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Float32: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60608) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:46.333082 [ 35670 ] {ad12a8b3-29d2-4030-b7cb-3dc31f5184b5} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Float32: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:47.220927 [ 35670 ] {29e69d42-bdbd-4512-98bc-342c2af0428c} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type String: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60670) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:47.225961 [ 35670 ] {29e69d42-bdbd-4512-98bc-342c2af0428c} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type String: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:47.738965 [ 35671 ] {37d37aad-393a-4f20-a86b-0486693767a0} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60630) (comment: 02433_default_expression_operator_in.sql) (in query: -- Ensure that a table name cannot be passed to IN as string literal create table test (n int, m default n in 'default.table_name') engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357c6d05 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b2aab5 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033af5362 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b269e8 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0eade 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 19. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:47.741205 [ 35671 ] {37d37aad-393a-4f20-a86b-0486693767a0} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357c6d05 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b2aab5 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033af5362 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b269e8 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0eade 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 19. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:47.763649 [ 35671 ] {f69c93de-9e9f-4dca-8f80-c3b8c082b89e} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60630) (comment: 02433_default_expression_operator_in.sql) (in query: create table test (n int, m default in(n, 'default.table_name')) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357c6d05 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b2aab5 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033af5362 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b269e8 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0eade 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 19. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:47.765623 [ 35671 ] {f69c93de-9e9f-4dca-8f80-c3b8c082b89e} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357c6d05 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b2aab5 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033af5362 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b269e8 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0eade 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 19. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:48.019015 [ 16275 ] {19a58e3e-df1d-4aba-8ffa-dc9eac989b3a} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type UInt64: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60686) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:48.023752 [ 16275 ] {19a58e3e-df1d-4aba-8ffa-dc9eac989b3a} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type UInt64: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:48.764139 [ 35047 ] {ee008688-f4e0-46cc-8deb-0cfd963787c9} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Map(UInt64, UInt64): (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60722) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Map(UInt64, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:48.768780 [ 35047 ] {ee008688-f4e0-46cc-8deb-0cfd963787c9} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Map(UInt64, UInt64): (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:414: DB::MsgPackVisitor::start_array(unsigned long) @ 0x000000003b28f9b8 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x000000003b2cb87c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c7af9 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:49.868864 [ 35669 ] {7a103b20-81c7-4109-a9f5-84dcd215e53e} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]'): Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000030cd0841 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000031959d0d 4. ./contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000031958e84 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x00000000318ca92c 6. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031953314 9. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 10. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 11. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031952f4d 14. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 16. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 18. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:49.871330 [ 35669 ] {7a103b20-81c7-4109-a9f5-84dcd215e53e} executeQuery: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60736) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000030cd0841 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000031959d0d 4. ./contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000031958e84 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x00000000318ca92c 6. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031953314 9. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 10. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 11. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031952f4d 14. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 16. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 18. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:49.874611 [ 35669 ] {7a103b20-81c7-4109-a9f5-84dcd215e53e} TCPHandler: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000030cd0841 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000031959d0d 4. ./contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000031958e84 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x00000000318ca92c 6. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031953314 9. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 10. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 11. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031952f4d 14. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 16. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 18. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:51.212558 [ 35669 ] {cbfb0873-bce7-4e58-a2fb-6a63210c05e2} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60766) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:51.218017 [ 35669 ] {cbfb0873-bce7-4e58-a2fb-6a63210c05e2} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:51.497668 [ 25641 ] {2485c682-e0d7-403d-89b7-bf4f5258933c} DistributedSink: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 1)), implicit conversion will be done. 2025.06.18 11:18:51.499221 [ 25643 ] {2485c682-e0d7-403d-89b7-bf4f5258933c} DistributedSink: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 1)), implicit conversion will be done. 2025.06.18 11:18:51.712837 [ 1190 ] {} test_b11r0hop.dist_01683.DistributedInsertQueue.default: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 0)), implicit conversion will be done 2025.06.18 11:18:51.719870 [ 1188 ] {} test_b11r0hop.dist_01683.DistributedInsertQueue.default: Structure does not match (remote: n Int8 Int8(size = 0), local: n UInt64 UInt64(size = 0)), implicit conversion will be done 2025.06.18 11:18:51.988728 [ 33053 ] {efb45c71-db5d-4216-bd37-c0a362fee22a} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000030cd0841 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000031959d0d 4. ./contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000031958e84 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x00000000318ca92c 6. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031953314 9. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 10. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 11. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackup() const @ 0x00000000318d3016 12. ./build_docker/./src/Backups/BackupImpl.cpp:763: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x00000000318dfe04 13. ./build_docker/./src/Backups/BackupImpl.cpp:709: DB::BackupImpl::readFile(std::pair> const&) const @ 0x00000000318def3a 14. ./build_docker/./src/Backups/BackupImpl.cpp:704: DB::BackupImpl::readFile(String const&) const @ 0x00000000318deefe 15. ./build_docker/./src/Backups/RestorerFromBackup.cpp:440: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000003187e36e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189b19f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x0000000031899e9a 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189a44e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:51.991177 [ 33053 ] {efb45c71-db5d-4216-bd37-c0a362fee22a} executeQuery: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60838) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: RESTORE TABLE data FROM S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000030cd0841 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000031959d0d 4. ./contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000031958e84 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x00000000318ca92c 6. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031953314 9. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 10. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 11. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackup() const @ 0x00000000318d3016 12. ./build_docker/./src/Backups/BackupImpl.cpp:763: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x00000000318dfe04 13. ./build_docker/./src/Backups/BackupImpl.cpp:709: DB::BackupImpl::readFile(std::pair> const&) const @ 0x00000000318def3a 14. ./build_docker/./src/Backups/BackupImpl.cpp:704: DB::BackupImpl::readFile(String const&) const @ 0x00000000318deefe 15. ./build_docker/./src/Backups/RestorerFromBackup.cpp:440: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000003187e36e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189b19f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x0000000031899e9a 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189a44e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:51.994198 [ 33053 ] {efb45c71-db5d-4216-bd37-c0a362fee22a} TCPHandler: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000030cd0841 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000031959d0d 4. ./contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000031958e84 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x00000000318ca92c 6. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000031953314 9. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 10. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 11. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackup() const @ 0x00000000318d3016 12. ./build_docker/./src/Backups/BackupImpl.cpp:763: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x00000000318dfe04 13. ./build_docker/./src/Backups/BackupImpl.cpp:709: DB::BackupImpl::readFile(std::pair> const&) const @ 0x00000000318def3a 14. ./build_docker/./src/Backups/BackupImpl.cpp:704: DB::BackupImpl::readFile(String const&) const @ 0x00000000318deefe 15. ./build_docker/./src/Backups/RestorerFromBackup.cpp:440: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000003187e36e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189b19f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x0000000031899e9a 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189a44e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:52.110158 [ 1597 ] {f83fa1e4-bb21-4d55-80d5-cf6e86e234d7} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36610) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:52.114994 [ 1597 ] {f83fa1e4-bb21-4d55-80d5-cf6e86e234d7} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:52.866031 [ 35675 ] {bda8982f-c66e-4245-812a-05cfec1492e2} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36640) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:52.871982 [ 35675 ] {bda8982f-c66e-4245-812a-05cfec1492e2} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:53.634735 [ 1590 ] {5b901a35-f839-45f6-98ed-96d0e6cddab2} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36662) (comment: 01098_msgpack_format.sh) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Array(UInt64)')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:53.639687 [ 1590 ] {5b901a35-f839-45f6-98ed-96d0e6cddab2} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:439: DB::MsgPackVisitor::start_map(unsigned int) @ 0x000000003b2905fc 5. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x000000003b2cbcfc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c9c6c 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:56.121445 [ 35659 ] {c761b402-31bb-44b7-8725-f96dfa7dc362} executeQuery: Code: 716. DB::Exception: Partition 20240103 is not empty. (CANNOT_FORGET_PARTITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36746) (comment: 02995_forget_partition.sh) (in query: alter table forget_partition forget partition '20240103';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5035: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd258 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:56.123205 [ 35659 ] {c761b402-31bb-44b7-8725-f96dfa7dc362} TCPHandler: Code: 716. DB::Exception: Partition 20240103 is not empty. (CANNOT_FORGET_PARTITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5035: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bd258 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:56.384778 [ 16275 ] {a43549b0-f087-4a98-863d-92adbdc908f7} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo'): Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x00000000319542a5 5. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 6. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 9. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:56.385963 [ 16275 ] {a43549b0-f087-4a98-863d-92adbdc908f7} executeQuery: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36760) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_0zi5qdq6/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x00000000319542a5 5. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 6. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 9. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:56.392911 [ 16275 ] {a43549b0-f087-4a98-863d-92adbdc908f7} TCPHandler: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x00000000319542a5 5. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 6. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 9. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:56.737109 [ 35659 ] {3537fd0f-2d21-4d5d-bffc-cb0dde241dfe} executeQuery: Code: 716. DB::Exception: Partition 20240203 is unknown. (CANNOT_FORGET_PARTITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36746) (comment: 02995_forget_partition.sh) (in query: alter table forget_partition forget partition '20240203';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7454: DB::StorageReplicatedMergeTree::forgetPartition(std::shared_ptr const&, std::shared_ptr) @ 0x0000000038994af6 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5319: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397cf6a0 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:56.738901 [ 35659 ] {3537fd0f-2d21-4d5d-bffc-cb0dde241dfe} TCPHandler: Code: 716. DB::Exception: Partition 20240203 is unknown. (CANNOT_FORGET_PARTITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7454: DB::StorageReplicatedMergeTree::forgetPartition(std::shared_ptr const&, std::shared_ptr) @ 0x0000000038994af6 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5319: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397cf6a0 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:58.353278 [ 35636 ] {b3caff46-0dfb-4d8f-964b-537f91735f8c} BackupsWorker: Failed to make backup Disk('backups', 'test_0zi5qdq6/backup_2'): Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_0zi5qdq6/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Backups/BackupInfo.cpp:111: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x0000000031701816 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d16c6 6. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x00000000319778ad 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 10. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 12. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 14. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:18:58.354534 [ 35636 ] {b3caff46-0dfb-4d8f-964b-537f91735f8c} executeQuery: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_0zi5qdq6/backup_2'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36808) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO Disk('backups', 'test_0zi5qdq6/backup_2') SETTINGS use_same_s3_credentials_for_base_backup=1, base_backup=Disk('backups', 'test_0zi5qdq6/backup_1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Backups/BackupInfo.cpp:111: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x0000000031701816 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d16c6 6. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x00000000319778ad 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 10. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 12. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 14. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:18:58.357660 [ 35636 ] {b3caff46-0dfb-4d8f-964b-537f91735f8c} TCPHandler: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_0zi5qdq6/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Backups/BackupInfo.cpp:111: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x0000000031701816 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d16c6 6. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x00000000319778ad 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 10. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 12. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 14. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:07.189246 [ 36000 ] {9a52121e-2cb9-4d20-bf7e-9b3ddb14b8e3} executeQuery: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37154) (comment: 03032_storage_memory_modify_settings.sql) (in query: ALTER TABLE memory MODIFY SETTING min_rows_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, DB::SettingFieldNumber const&>(int, FormatStringHelperImpl const&>::type, std::type_identity const&>::type>, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&) @ 0x00000000381b45ed 4. ./build_docker/./src/Storages/MemorySettings.cpp:55: DB::MemorySettings::sanityCheck() const @ 0x00000000381b1359 5. ./build_docker/./src/Storages/StorageMemory.cpp:0: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003858e9c9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:07.191378 [ 36000 ] {9a52121e-2cb9-4d20-bf7e-9b3ddb14b8e3} TCPHandler: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, DB::SettingFieldNumber const&>(int, FormatStringHelperImpl const&>::type, std::type_identity const&>::type>, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&) @ 0x00000000381b45ed 4. ./build_docker/./src/Storages/MemorySettings.cpp:55: DB::MemorySettings::sanityCheck() const @ 0x00000000381b1359 5. ./build_docker/./src/Storages/StorageMemory.cpp:0: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003858e9c9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:07.467142 [ 1597 ] {e518fcfd-3bca-42cf-a2f8-4ea0cb700c61} executeQuery: Code: 36. DB::Exception: Second and third arguments must be the same length: In scope SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37236) (comment: 02353_translate.sql) (in query: SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x000000001c90de79 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c907964 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:19:07.469068 [ 1597 ] {e518fcfd-3bca-42cf-a2f8-4ea0cb700c61} TCPHandler: Code: 36. DB::Exception: Second and third arguments must be the same length: In scope SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x000000001c90de79 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c907964 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:19:07.627507 [ 36000 ] {4d85dbbd-d0af-4ad4-b793-8691efda110f} executeQuery: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37154) (comment: 03032_storage_memory_modify_settings.sql) (in query: ALTER TABLE memory MODIFY SETTING min_bytes_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, DB::SettingFieldNumber const&>(int, FormatStringHelperImpl const&>::type, std::type_identity const&>::type>, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&) @ 0x00000000381b45ed 4. ./build_docker/./src/Storages/MemorySettings.cpp:48: DB::MemorySettings::sanityCheck() const @ 0x00000000381b1203 5. ./build_docker/./src/Storages/StorageMemory.cpp:0: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003858e9c9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:07.629798 [ 36000 ] {4d85dbbd-d0af-4ad4-b793-8691efda110f} TCPHandler: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception const&, DB::SettingFieldNumber const&>(int, FormatStringHelperImpl const&>::type, std::type_identity const&>::type>, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&) @ 0x00000000381b45ed 4. ./build_docker/./src/Storages/MemorySettings.cpp:48: DB::MemorySettings::sanityCheck() const @ 0x00000000381b1203 5. ./build_docker/./src/Storages/StorageMemory.cpp:0: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003858e9c9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:08.286944 [ 1597 ] {7a2d2cc7-2028-416c-a1a8-40c097da771e} executeQuery: Code: 36. DB::Exception: Second and third arguments must be the same length: In scope SELECT translateUTF8('abc', 'efg', ''). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37236) (comment: 02353_translate.sql) (in query: SELECT translateUTF8('abc', 'efg', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::TranslateUTF8Impl::fillMapWithValues(std::array&, HashMapTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>&, String const&, String const&) @ 0x000000001c910cdd 5. DB::TranslateUTF8Impl::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, String const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000001c90e1df 6. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c90b7d6 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:19:08.288784 [ 1597 ] {7a2d2cc7-2028-416c-a1a8-40c097da771e} TCPHandler: Code: 36. DB::Exception: Second and third arguments must be the same length: In scope SELECT translateUTF8('abc', 'efg', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::TranslateUTF8Impl::fillMapWithValues(std::array&, HashMapTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>&, String const&, String const&) @ 0x000000001c910cdd 5. DB::TranslateUTF8Impl::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, String const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000001c90e1df 6. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c90b7d6 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:19:25.673908 [ 35666 ] {13282627-1525-45a7-86af-5b71586438fd} executeQuery: Code: 44. DB::Exception: Illegal column UInt32 of argument of aggregation state multiply. Should be integer constant. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47570) (comment: 00647_multiply_aggregation_state.sql) (in query: SELECT sumMerge(y * a) FROM (SELECT a, sumState(b) AS y FROM mult_aggregation GROUP BY a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionBinaryArithmetic::executeAggregateMultiply(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000189415f9 5. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001893f1ff 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfee92 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:25.676483 [ 35666 ] {13282627-1525-45a7-86af-5b71586438fd} TCPHandler: Code: 44. DB::Exception: Illegal column UInt32 of argument of aggregation state multiply. Should be integer constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionBinaryArithmetic::executeAggregateMultiply(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000189415f9 5. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001893f1ff 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfee92 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:34.301230 [ 1597 ] {42960f3b-9865-4c1e-8a24-d5841f34be0e} executeQuery: Code: 407. DB::Exception: Numeric overflow: While executing ConvertingAggregatedToChunksTransform. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57800) (comment: 02029_quantile_sanitizer.sql) (in query: SELECT quantileTDigestWeighted(-0.)(toDateTime(10000000000.), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/AggregateFunctions/QuantileTDigest.h:0: unsigned int DB::QuantileTDigest::getImpl(double) @ 0x000000002c620da7 5. ./src/Common/PODArray.h:427: DB::AggregateFunctionQuantile, DB::NameQuantileTDigestWeighted, true, void, false, false>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002c79f828 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000033da3030 7. ./build_docker/./src/Interpreters/Aggregator.cpp:2144: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000033b6fbd4 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:470: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x000000003b789b6f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000003b77fb9d 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:34.305232 [ 1597 ] {42960f3b-9865-4c1e-8a24-d5841f34be0e} TCPHandler: Code: 407. DB::Exception: Numeric overflow: While executing ConvertingAggregatedToChunksTransform. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/AggregateFunctions/QuantileTDigest.h:0: unsigned int DB::QuantileTDigest::getImpl(double) @ 0x000000002c620da7 5. ./src/Common/PODArray.h:427: DB::AggregateFunctionQuantile, DB::NameQuantileTDigestWeighted, true, void, false, false>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002c79f828 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000033da3030 7. ./build_docker/./src/Interpreters/Aggregator.cpp:2144: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000033b6fbd4 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:470: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x000000003b789b6f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000003b77fb9d 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:37.985662 [ 612 ] {8eba8e30-6916-4ced-9780-f2adb729ab00} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38704). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38704) (comment: 01731_async_task_queue_wait.sh) (in query: SELECT `__table1`.`number` + sleep(0.3) AS `x` FROM `system`.`numbers` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:37.990560 [ 612 ] {8eba8e30-6916-4ced-9780-f2adb729ab00} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38704). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:19:37.990922 [ 612 ] {8eba8e30-6916-4ced-9780-f2adb729ab00} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38704). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:37.991847 [ 612 ] {8eba8e30-6916-4ced-9780-f2adb729ab00} TCPHandler: Client has gone away. 2025.06.18 11:19:38.308393 [ 1597 ] {269bfecc-ff73-4404-97ff-2b7687ca9814} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:56800). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56800) (comment: 01731_async_task_queue_wait.sh) (in query: SELECT `__table1`.`number` + sleep(0.3) AS `x` FROM `system`.`numbers` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1981 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:38.312869 [ 1597 ] {269bfecc-ff73-4404-97ff-2b7687ca9814} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:56800). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:19:38.313223 [ 1597 ] {269bfecc-ff73-4404-97ff-2b7687ca9814} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:56800). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1981 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:38.314007 [ 1597 ] {269bfecc-ff73-4404-97ff-2b7687ca9814} TCPHandler: Client has gone away. 2025.06.18 11:19:40.106220 [ 16279 ] {f67f9d30-a177-4ebc-918c-d9c1db429690} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:56452). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56452) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1981 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:40.108562 [ 16279 ] {f67f9d30-a177-4ebc-918c-d9c1db429690} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:56452). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9bbd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1981 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:40.109217 [ 16279 ] {f67f9d30-a177-4ebc-918c-d9c1db429690} TCPHandler: Client has gone away. 2025.06.18 11:19:40.606445 [ 1590 ] {acc938fb-a8ae-49c1-ba9d-74f93a35f4dd} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:56468). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56468) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000003abd30c7 6. ./build_docker/./src/Server/TCPHandler.cpp:1166: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1778 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:40.609249 [ 1590 ] {acc938fb-a8ae-49c1-ba9d-74f93a35f4dd} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:56468). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000003abd30c7 6. ./build_docker/./src/Server/TCPHandler.cpp:1166: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1778 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:40.610064 [ 1590 ] {acc938fb-a8ae-49c1-ba9d-74f93a35f4dd} TCPHandler: Client has gone away. 2025.06.18 11:19:40.616569 [ 16279 ] {bcaa50c1-bf9b-45e2-94de-e82b26df6e26} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:56480). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56480) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000003abd30c7 6. ./contrib/llvm-project/libcxx/include/__mutex_base:143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd2232 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:40.618974 [ 16279 ] {bcaa50c1-bf9b-45e2-94de-e82b26df6e26} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:56480). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000003abd30c7 6. ./contrib/llvm-project/libcxx/include/__mutex_base:143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd2232 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:40.619635 [ 16279 ] {bcaa50c1-bf9b-45e2-94de-e82b26df6e26} TCPHandler: Client has gone away. 2025.06.18 11:19:49.187085 [ 35659 ] {f518628b-d7db-413d-9459-8f7db486b58d} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Array(String)) of bloom filter index. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49394) (comment: 00908_bloom_filter_index.sh) (in query: CREATE TABLE bloom_filter_idx_na (`na` Array(Array(String)), INDEX bf na TYPE bloom_filter(0.1) GRANULARITY 1) ENGINE = MergeTree ORDER BY na SETTINGS index_granularity = 43971, min_bytes_for_wide_part = 583630380, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 128462790, compact_parts_max_bytes_to_buffer = 61904189, compact_parts_max_granules_to_buffer = 26, compact_parts_merge_max_bytes_to_prefetch_part = 31966985, merge_max_block_size = 11763, old_parts_lifetime = 404., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1530255050, index_granularity_bytes = 22921046, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 82184, primary_key_compress_block_size = 40369), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/BloomFilter.cpp:131: DB::BloomFilter::getPrimitiveType(std::shared_ptr const&) @ 0x000000003484954e 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:0: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039b3ddd5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:49.191236 [ 35659 ] {f518628b-d7db-413d-9459-8f7db486b58d} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Array(String)) of bloom filter index. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/BloomFilter.cpp:131: DB::BloomFilter::getPrimitiveType(std::shared_ptr const&) @ 0x000000003484954e 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:0: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000039b3ddd5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039ac836e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039ab936e 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396bd981 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396a61bd 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b45 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.300853 [ 1597 ] {a600fa2d-0f13-4618-b694-b505a28b5fc6} executeQuery: Code: 387. DB::Exception: Dictionary test_092vstbw.test_dict already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54050) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE TABLE test_dict (`y` Int64) ENGINE = MergeTree ORDER BY y SETTINGS index_granularity = 10931, min_bytes_for_wide_part = 420316861, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 120315515, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 5087839, merge_max_block_size = 4742, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7528706740, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 57, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 28369584, concurrent_part_removal_threshold = 56, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 55708, primary_key_compress_block_size = 47207), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da783 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.303014 [ 1597 ] {a600fa2d-0f13-4618-b694-b505a28b5fc6} TCPHandler: Code: 387. DB::Exception: Dictionary test_092vstbw.test_dict already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da783 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.320592 [ 1597 ] {b4257d1a-4ff6-4d32-8a74-51fe9693f199} executeQuery: Code: 57. DB::Exception: Table test_092vstbw.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54050) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE DICTIONARY test_table (y String, value UInt64 DEFAULT 0) PRIMARY KEY y SOURCE(CLICKHOUSE(TABLE 'test_table')) LAYOUT(DIRECT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.322584 [ 1597 ] {b4257d1a-4ff6-4d32-8a74-51fe9693f199} TCPHandler: Code: 57. DB::Exception: Table test_092vstbw.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.349519 [ 1597 ] {2ff67da5-dedc-4961-ad78-20eaaddc40f5} executeQuery: Code: 387. DB::Exception: Dictionary test_092vstbw.test_dict already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54050) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE DICTIONARY test_dict (y String, value UInt64 DEFAULT 0) PRIMARY KEY y SOURCE(CLICKHOUSE(TABLE 'test_table')) LAYOUT(DIRECT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da783 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.351395 [ 1597 ] {2ff67da5-dedc-4961-ad78-20eaaddc40f5} TCPHandler: Code: 387. DB::Exception: Dictionary test_092vstbw.test_dict already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da783 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.383671 [ 1597 ] {523aefe5-cb47-4bf6-b13d-d53978b09330} executeQuery: Code: 57. DB::Exception: Table test_092vstbw.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54050) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE TABLE test_table (`y` Int64) ENGINE = MergeTree ORDER BY y SETTINGS index_granularity = 10931, min_bytes_for_wide_part = 420316861, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 120315515, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 5087839, merge_max_block_size = 4742, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7528706740, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 57, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 28369584, concurrent_part_removal_threshold = 56, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 55708, primary_key_compress_block_size = 47207), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:54.386182 [ 1597 ] {523aefe5-cb47-4bf6-b13d-d53978b09330} TCPHandler: Code: 57. DB::Exception: Table test_092vstbw.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:56.041950 [ 35047 ] {085c33ac-59aa-4f89-b53d-e3bae7de507f} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54124) (comment: 01714_alter_drop_version.sql) (in query: ALTER TABLE alter_drop_version DROP COLUMN ver;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3349: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000397579b0 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:56.044126 [ 35047 ] {085c33ac-59aa-4f89-b53d-e3bae7de507f} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3349: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000397579b0 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:56.517710 [ 35047 ] {bc5c98ab-d46a-4bf8-897f-10c93da517f0} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54124) (comment: 01714_alter_drop_version.sql) (in query: ALTER TABLE alter_drop_version RENAME COLUMN ver TO rev;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3354: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039757c5a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:56.519988 [ 35047 ] {bc5c98ab-d46a-4bf8-897f-10c93da517f0} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3354: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039757c5a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:57.195807 [ 1534 ] {df796fb4-4e97-48e2-81fe-1505e54faf6b} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Array(Nullable(String)). In query WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54166) (comment: 03144_invalid_filter.sql) (in query: WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY x -> compound_value.* FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319dd0b7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033583a4a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x0000000033582d83 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e768 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:57.198611 [ 1534 ] {df796fb4-4e97-48e2-81fe-1505e54faf6b} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Array(Nullable(String)). In query WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319dd0b7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033583a4a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x0000000033582d83 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e768 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:57.657430 [ 1534 ] {5b3df4d1-15f7-4013-8345-48ccaf0d5591} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647'. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54166) (comment: 03144_invalid_filter.sql) (in query: DESCRIBE TABLE (SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319dd0b7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033583a4a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x0000000033582d83 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e768 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:135: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x00000000359dc53e 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359daa27 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:57.660828 [ 1534 ] {5b3df4d1-15f7-4013-8345-48ccaf0d5591} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647'. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319dd0b7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033583a4a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x0000000033582d83 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e768 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:135: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x00000000359dc53e 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359daa27 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:58.124208 [ 35674 ] {36b71c87-3e24-4303-bb95-3103d013f546} executeQuery: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54212) (comment: 01804_uniq_up_to_ubsan.sql) (in query: SELECT uniqUpTo(1e100)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x0000000020054e59 5. ./src/Core/Field.h:0: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x000000002b5a18ae 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:305: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ecae189 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:19:58.126263 [ 35674 ] {36b71c87-3e24-4303-bb95-3103d013f546} TCPHandler: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x0000000020054e59 5. ./src/Core/Field.h:0: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x000000002b5a18ae 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:305: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ecae189 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:19:58.153530 [ 35674 ] {097f4409-4285-4381-bc0f-33cc29bbd973} executeQuery: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54212) (comment: 01804_uniq_up_to_ubsan.sql) (in query: SELECT uniqUpTo(-1e100)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x0000000020054e59 5. ./src/Core/Field.h:0: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x000000002b5a18ae 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:305: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ecae189 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:19:58.155613 [ 35674 ] {097f4409-4285-4381-bc0f-33cc29bbd973} TCPHandler: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x0000000020054e59 5. ./src/Core/Field.h:0: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x000000002b5a18ae 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:305: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ecae189 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:19:58.816349 [ 1534 ] {65da4aa1-db87-4b70-b781-d176bd7554d5} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:19:59.261494 [ 1590 ] {3fbe86ab-f0fb-45f1-9a31-14401a7ce832} executeQuery: Code: 36. DB::Exception: Data type have to be specified for column `value` to add. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54226) (comment: 01079_alter_default_zookeeper_long.sql) (in query: -- Cannot add column without type ALTER TABLE alter_default ADD COLUMN value DEFAULT '10';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1329: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a34fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:59.263687 [ 1590 ] {3fbe86ab-f0fb-45f1-9a31-14401a7ce832} TCPHandler: Code: 36. DB::Exception: Data type have to be specified for column `value` to add. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1329: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a34fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:59.381062 [ 1534 ] {65da4aa1-db87-4b70-b781-d176bd7554d5} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54230) (comment: 01956_skip_unavailable_shards_excessive_attempts.sh) (in query: select * from remote('255.255.255.255', system.one) settings use_hedged_requests=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d3ddca 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:170: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038d37018 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fddff29 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdde41a 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:19:59.384931 [ 1534 ] {65da4aa1-db87-4b70-b781-d176bd7554d5} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d3ddca 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:170: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038d37018 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fddff29 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdde41a 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:00.259084 [ 25385 ] {6fa1e02f-b312-4cf7-b0df-04c1133f89a6} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:20:01.054053 [ 1534 ] {4c4b22f1-59d9-4bd6-aadc-b19a11379ef5} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:20:01.158535 [ 25665 ] {4c4b22f1-59d9-4bd6-aadc-b19a11379ef5} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:20:01.978667 [ 1590 ] {4bb363ed-dcf3-4771-9bd2-62081272aa8a} executeQuery: Code: 6. DB::Exception: Cannot parse string 'q' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: While processing _CAST('q' AS bad_column_tmp_alter3466836433308551313, 'UInt8') AS bad_column: default expression and column type are incompatible. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54226) (comment: 01079_alter_default_zookeeper_long.sql) (in query: ALTER TABLE alter_default ADD COLUMN bad_column UInt8 DEFAULT 'q';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008795888 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876b0ff 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321ab0e 20. ./build_docker/./src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000332182ad 21. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 22. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 23. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 24. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 26. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 27. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 28. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 30. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 31. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 2025.06.18 11:20:01.981303 [ 1590 ] {4bb363ed-dcf3-4771-9bd2-62081272aa8a} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'q' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: While processing _CAST('q' AS bad_column_tmp_alter3466836433308551313, 'UInt8') AS bad_column: default expression and column type are incompatible. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008795888 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876b0ff 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321ab0e 20. ./build_docker/./src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000332182ad 21. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 22. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 23. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 24. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 26. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 27. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 28. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 30. ./src/Core/Block.h:25: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809f527 31. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 2025.06.18 11:20:03.223990 [ 1590 ] {c7d981cf-51b6-474c-b00c-6d03ad76c673} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: While processing _CAST('0' AS other_date_tmp_alter14067773560387424302, 'DateTime') AS other_date: default expression and column type are incompatible. (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54226) (comment: 01079_alter_default_zookeeper_long.sql) (in query: ALTER TABLE alter_default MODIFY COLUMN other_date DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000201d44d8 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000009624d7d 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008e88e35 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e2e9a9 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 21. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321ab0e 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000332182ad 23. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 24. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 25. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 27. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 28. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 29. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 30. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 31. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 2025.06.18 11:20:03.226299 [ 1590 ] {c7d981cf-51b6-474c-b00c-6d03ad76c673} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: While processing _CAST('0' AS other_date_tmp_alter14067773560387424302, 'DateTime') AS other_date: default expression and column type are incompatible. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000201d44d8 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000009624d7d 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008e88e35 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e2e9a9 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 21. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000003321ab0e 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000332182ad 23. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 24. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 25. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 27. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 28. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 29. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 30. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 31. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 2025.06.18 11:20:03.883846 [ 35005 ] {97377a0c-e387-4c9d-a189-d591f688e681} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'fields.value' in scope SELECT fields.name, fields.value FROM (SELECT fields.name FROM test_table). Maybe you meant: ['fields.name']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58142) (comment: 02494_analyzer_compound_expression_crash_fix.sql) (in query: SELECT fields.name, fields.value FROM (SELECT fields.name FROM test_table);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:03.885972 [ 35005 ] {97377a0c-e387-4c9d-a189-d591f688e681} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'fields.value' in scope SELECT fields.name, fields.value FROM (SELECT fields.name FROM test_table). Maybe you meant: ['fields.name']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:10.645662 [ 1590 ] {b2e42f8b-1ecd-4cd8-b2c1-626bd45f4e72} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (20) of function h3GetPentagonIndexes is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3GetPentagonIndexes(20) AS indexes. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58270) (comment: 02212_h3_get_pentagon_indexes.sql) (in query: SELECT h3GetPentagonIndexes(20) AS indexes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3GetPentagonIndexes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012355640 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:10.648114 [ 1590 ] {b2e42f8b-1ecd-4cd8-b2c1-626bd45f4e72} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (20) of function h3GetPentagonIndexes is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3GetPentagonIndexes(20) AS indexes. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3GetPentagonIndexes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012355640 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:12.491298 [ 1534 ] {dfe54cf4-09cd-468f-9674-68f31df1893a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.493426 [ 1534 ] {dfe54cf4-09cd-468f-9674-68f31df1893a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.520959 [ 1534 ] {56a1ea23-bc51-4dc3-9c16-9c1c4d280989} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.523014 [ 1534 ] {56a1ea23-bc51-4dc3-9c16-9c1c4d280989} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.550726 [ 1534 ] {b1150179-4739-4e54-b2f6-42617420faae} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.552786 [ 1534 ] {b1150179-4739-4e54-b2f6-42617420faae} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.581370 [ 1534 ] {6c749523-6e67-4d5d-9d1c-efb37e492222} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.583433 [ 1534 ] {6c749523-6e67-4d5d-9d1c-efb37e492222} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.617223 [ 1534 ] {8036fb55-8a67-451c-a635-7d8e4ca032b5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.619500 [ 1534 ] {8036fb55-8a67-451c-a635-7d8e4ca032b5} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.647244 [ 1534 ] {2dcd5113-9a42-4678-8f27-fa20ef577530} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.649302 [ 1534 ] {2dcd5113-9a42-4678-8f27-fa20ef577530} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.677610 [ 1534 ] {9e14107b-6005-425b-a4d4-855071ed5863} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.679626 [ 1534 ] {9e14107b-6005-425b-a4d4-855071ed5863} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.708463 [ 1534 ] {6edce044-194d-4805-937b-b547d72ec9f0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.710486 [ 1534 ] {6edce044-194d-4805-937b-b547d72ec9f0} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.735960 [ 1534 ] {28d2644c-4b35-438f-8689-7273d2c1d6a1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32('1980', '10');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.738570 [ 1534 ] {28d2644c-4b35-438f-8689-7273d2c1d6a1} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.762185 [ 1534 ] {f7c1ee9c-7799-4ebc-abde-895a6fcf5598} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32('-1980', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.764129 [ 1534 ] {f7c1ee9c-7799-4ebc-abde-895a6fcf5598} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.788265 [ 1534 ] {66797ec4-34a7-4185-b63a-aa3d62043c29} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32('aa', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.790279 [ 1534 ] {66797ec4-34a7-4185-b63a-aa3d62043c29} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.811978 [ 1534 ] {b9a5e53d-c857-40a5-b0ae-73f1b915cd66} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58306) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(1994, 'aa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:12.814092 [ 1534 ] {b9a5e53d-c857-40a5-b0ae-73f1b915cd66} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015f998f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:14.627298 [ 35671 ] {6e084a1b-6df1-4e20-a197-2b492af0d831} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50804) (comment: 02797_range_nullable.sql) (in query: SELECT range(Null::Nullable(UInt64), 10::Nullable(UInt64), 2::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:14.629839 [ 35671 ] {6e084a1b-6df1-4e20-a197-2b492af0d831} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:14.665864 [ 35671 ] {b90113fe-2200-4c26-94f1-b47d14ff8774} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50804) (comment: 02797_range_nullable.sql) (in query: SELECT range(0::Nullable(UInt64), Null::Nullable(UInt64), 2::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:14.667943 [ 35671 ] {b90113fe-2200-4c26-94f1-b47d14ff8774} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:14.700937 [ 35671 ] {1bd9f480-9d3e-4b12-a9d4-2c00451922c6} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50804) (comment: 02797_range_nullable.sql) (in query: SELECT range(0::Nullable(UInt64), 10::Nullable(UInt64), Null::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:14.702846 [ 35671 ] {1bd9f480-9d3e-4b12-a9d4-2c00451922c6} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:15.423223 [ 35671 ] {9893721e-10d9-42d8-a0be-3b6c0f2bed0d} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50804) (comment: 02797_range_nullable.sql) (in query: SELECT range(Null::Nullable(UInt8), materialize(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:15.425328 [ 35671 ] {9893721e-10d9-42d8-a0be-3b6c0f2bed0d} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001fe9cc03 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe93446 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:21.890654 [ 35673 ] {afe50fc2-eeb1-448b-9034-6ee838ce0008} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51056) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a5502 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:21.896074 [ 35673 ] {afe50fc2-eeb1-448b-9034-6ee838ce0008} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a5502 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:23.215042 [ 35673 ] {251df6a8-7c72-4b99-a5ad-4736211f15b8} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51056) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictHas('02176_test_simple_key_dictionary', [0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096da681 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:23.217292 [ 35673 ] {251df6a8-7c72-4b99-a5ad-4736211f15b8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096da681 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:23.858866 [ 35673 ] {0f2f869c-f00b-42d2-988a-841a634caaa9} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_complex_key_dictionary', 'value', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51056) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictGet('02176_test_complex_key_dictionary', 'value', tuple([0], '0'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a5502 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:23.860982 [ 35673 ] {0f2f869c-f00b-42d2-988a-841a634caaa9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_complex_key_dictionary', 'value', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a5502 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:24.275577 [ 35673 ] {cb23990c-c276-44ef-aa04-8cfc9e4998ee} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_complex_key_dictionary', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51056) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictHas('02176_test_complex_key_dictionary', tuple([0], '0'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096da681 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:24.277610 [ 35673 ] {cb23990c-c276-44ef-aa04-8cfc9e4998ee} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_complex_key_dictionary', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008888287 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b8823 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000357b983c 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d534f4 19. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096da681 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 21. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 23. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 28. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 31. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 2025.06.18 11:20:27.231731 [ 35675 ] {efdfee9e-6026-4bf1-873a-b43b854eac10} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35222) (comment: 01528_allow_nondeterministic_optimize_skip_unused_shards.sql) (in query: select * from dist_01528 where dummy = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264d59 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:27.233945 [ 35675 ] {efdfee9e-6026-4bf1-873a-b43b854eac10} TCPHandler: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000038264d59 5. ./build_docker/./src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000038260417 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f5fc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:28.356240 [ 35671 ] {482d2f25-4d15-4e38-99a8-603f98356154} executeQuery: Code: 277. DB::Exception: Primary key (id, date) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35236) (comment: 00808_not_optimize_predicate.sql) (in query: SELECT * FROM (SELECT * FROM test_00808 LIMIT 1) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf130f9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf18ae0 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:28.359041 [ 35671 ] {482d2f25-4d15-4e38-99a8-603f98356154} TCPHandler: Code: 277. DB::Exception: Primary key (id, date) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf130f9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf18ae0 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:28.429806 [ 35671 ] {2949f889-d063-47ef-b78d-7f56c752cb43} executeQuery: Code: 277. DB::Exception: Primary key (id, date) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35236) (comment: 00808_not_optimize_predicate.sql) (in query: SELECT * FROM (SELECT id FROM test_00808 GROUP BY id LIMIT 1 BY id) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf130f9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf18ae0 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:28.432574 [ 35671 ] {2949f889-d063-47ef-b78d-7f56c752cb43} TCPHandler: Code: 277. DB::Exception: Primary key (id, date) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf130f9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf18ae0 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:28.932795 [ 35636 ] {d5c69791-4345-4c46-b523-b4c60b252a8f} executeQuery: Code: 69. DB::Exception: Overflow in internal computations in function groupArrayResample. Too large arguments. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35284) (comment: 01463_resample_overflow.sql) (in query: select groupArrayResample(-9223372036854775808, 9223372036854775807, 9223372036854775807)(number, toInt64(number)) FROM numbers(7);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/AggregateFunctions/Combinators/AggregateFunctionResample.h:69: DB::AggregateFunctionResample::AggregateFunctionResample(std::shared_ptr, long, long, unsigned long, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdba603 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdb9366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::AggregateFunctionCombinatorResample::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fdafcac 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:20:28.935111 [ 35636 ] {d5c69791-4345-4c46-b523-b4c60b252a8f} TCPHandler: Code: 69. DB::Exception: Overflow in internal computations in function groupArrayResample. Too large arguments. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./src/AggregateFunctions/Combinators/AggregateFunctionResample.h:69: DB::AggregateFunctionResample::AggregateFunctionResample(std::shared_ptr, long, long, unsigned long, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdba603 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdb9366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::AggregateFunctionCombinatorResample::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fdafcac 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306de9f5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:20:30.110060 [ 35675 ] {0d0589a9-0c35-470f-9c3f-e4409e8eca06} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BIT_AND();) 2025.06.18 11:20:30.113658 [ 35675 ] {0d0589a9-0c35-470f-9c3f-e4409e8eca06} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.289928 [ 35675 ] {0427a35e-0646-47e2-8656-0d31c302cdf3} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BIT_OR();) 2025.06.18 11:20:30.293459 [ 35675 ] {0427a35e-0646-47e2-8656-0d31c302cdf3} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.318181 [ 35675 ] {6b40d83e-9e80-4734-986a-45dc4fa8d77c} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BIT_XOR();) 2025.06.18 11:20:30.321568 [ 35675 ] {6b40d83e-9e80-4734-986a-45dc4fa8d77c} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.347015 [ 35675 ] {d95c749a-508d-4340-a20d-f356cb30c1fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 0, should be 1: In scope SELECT BLAKE3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BLAKE3();) 2025.06.18 11:20:30.350649 [ 35675 ] {d95c749a-508d-4340-a20d-f356cb30c1fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 0, should be 1: In scope SELECT BLAKE3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.381912 [ 35675 ] {8fb3f605-4a5f-480a-8ceb-239e9fa381e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHARACTER_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CHARACTER_LENGTH();) 2025.06.18 11:20:30.385348 [ 35675 ] {8fb3f605-4a5f-480a-8ceb-239e9fa381e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHARACTER_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.411367 [ 35675 ] {ed36bcbb-5f14-4f7a-ada7-d62a3cc057a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHAR_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CHAR_LENGTH();) 2025.06.18 11:20:30.414993 [ 35675 ] {ed36bcbb-5f14-4f7a-ada7-d62a3cc057a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHAR_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.440020 [ 35675 ] {28c7e194-1dd0-4f8e-bda4-37a36dbe303c} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT COVAR_POP();) 2025.06.18 11:20:30.443415 [ 35675 ] {28c7e194-1dd0-4f8e-bda4-37a36dbe303c} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.469702 [ 35675 ] {3bae629f-c0ec-4a48-a7dc-1f438e1eac37} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT COVAR_SAMP();) 2025.06.18 11:20:30.473375 [ 35675 ] {3bae629f-c0ec-4a48-a7dc-1f438e1eac37} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.498161 [ 35675 ] {0e4b1697-192b-40b5-98fb-a9843a5647dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 0, should be 1: In scope SELECT CRC32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CRC32();) 2025.06.18 11:20:30.501848 [ 35675 ] {0e4b1697-192b-40b5-98fb-a9843a5647dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 0, should be 1: In scope SELECT CRC32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.528338 [ 35675 ] {6bcbe7cc-4926-4372-88f4-2b8be49fa9ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 0, should be 1: In scope SELECT CRC32IEEE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CRC32IEEE();) 2025.06.18 11:20:30.531693 [ 35675 ] {6bcbe7cc-4926-4372-88f4-2b8be49fa9ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 0, should be 1: In scope SELECT CRC32IEEE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.556128 [ 35675 ] {5aca6801-98f1-482e-8644-5cb465caf2dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 0, should be 1: In scope SELECT CRC64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CRC64();) 2025.06.18 11:20:30.559698 [ 35675 ] {5aca6801-98f1-482e-8644-5cb465caf2dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 0, should be 1: In scope SELECT CRC64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.639733 [ 35675 ] {cf8b29dc-3c14-4a51-908f-ef1a537b6fda} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT DATE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE();) 2025.06.18 11:20:30.643423 [ 35675 ] {cf8b29dc-3c14-4a51-908f-ef1a537b6fda} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT DATE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.671739 [ 35675 ] {9d20defb-928c-4b8b-a0a5-20c3e81d948a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE_DIFF();) 2025.06.18 11:20:30.675602 [ 35675 ] {9d20defb-928c-4b8b-a0a5-20c3e81d948a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.701822 [ 35675 ] {74d0d15a-f04c-41e0-871c-cdfc9691dce0} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_FORMAT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE_FORMAT();) 2025.06.18 11:20:30.705356 [ 35675 ] {74d0d15a-f04c-41e0-871c-cdfc9691dce0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_FORMAT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.730698 [ 35675 ] {226ae79e-1107-4d15-a503-acaf059d1df0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_TRUNC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE_TRUNC();) 2025.06.18 11:20:30.734398 [ 35675 ] {226ae79e-1107-4d15-a503-acaf059d1df0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_TRUNC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.761896 [ 35675 ] {364cc90f-5dfc-42f9-af61-ab31e85ff02b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAY();) 2025.06.18 11:20:30.765233 [ 35675 ] {364cc90f-5dfc-42f9-af61-ab31e85ff02b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.793912 [ 35675 ] {1c8b5c0d-dac9-40eb-8a86-26ad96cf83ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFMONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAYOFMONTH();) 2025.06.18 11:20:30.797976 [ 35675 ] {1c8b5c0d-dac9-40eb-8a86-26ad96cf83ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFMONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.831806 [ 35675 ] {affa2642-291f-4b60-9276-c5fa3b33e6bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT DAYOFWEEK(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAYOFWEEK();) 2025.06.18 11:20:30.835849 [ 35675 ] {affa2642-291f-4b60-9276-c5fa3b33e6bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT DAYOFWEEK(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.866408 [ 35675 ] {25ba2010-8c71-4e73-ba59-2b1a364fdcbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFYEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAYOFYEAR();) 2025.06.18 11:20:30.870238 [ 35675 ] {25ba2010-8c71-4e73-ba59-2b1a364fdcbe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFYEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.898491 [ 35675 ] {fc0a45da-74b0-4909-8008-c7cdd417f72b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT FORMAT_BYTES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FORMAT_BYTES();) 2025.06.18 11:20:30.902787 [ 35675 ] {fc0a45da-74b0-4909-8008-c7cdd417f72b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT FORMAT_BYTES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:30.978814 [ 35675 ] {aa156e62-8f16-470f-bc80-427fbf8cebe3} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT FROM_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FROM_BASE64();) 2025.06.18 11:20:30.982034 [ 35675 ] {aa156e62-8f16-470f-bc80-427fbf8cebe3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT FROM_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.009265 [ 35675 ] {f7572ac2-2528-4123-b703-756bf28bcc38} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT FROM_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FROM_DAYS();) 2025.06.18 11:20:31.012594 [ 35675 ] {f7572ac2-2528-4123-b703-756bf28bcc38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT FROM_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.036542 [ 35675 ] {8e45fdb7-f4ae-44ec-afad-4f14b608202b} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT FROM_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FROM_UNIXTIME();) 2025.06.18 11:20:31.039787 [ 35675 ] {8e45fdb7-f4ae-44ec-afad-4f14b608202b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT FROM_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.064364 [ 35675 ] {d810c038-9f8a-4f8c-bdbd-ea11a5805b70} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT HOUR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT HOUR();) 2025.06.18 11:20:31.067506 [ 35675 ] {d810c038-9f8a-4f8c-bdbd-ea11a5805b70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT HOUR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.092684 [ 35675 ] {1d10bbba-ea6b-441e-9aab-298a9780fecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET6_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET6_ATON();) 2025.06.18 11:20:31.096275 [ 35675 ] {1d10bbba-ea6b-441e-9aab-298a9780fecb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET6_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.121986 [ 35675 ] {232e62ca-6546-4435-98d3-f3c5edf3b4cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT INET6_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET6_NTOA();) 2025.06.18 11:20:31.125499 [ 35675 ] {232e62ca-6546-4435-98d3-f3c5edf3b4cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT INET6_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.150001 [ 35675 ] {9dbfac21-2b0b-4d66-b3e8-3037d8bdc2f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET_ATON();) 2025.06.18 11:20:31.153376 [ 35675 ] {9dbfac21-2b0b-4d66-b3e8-3037d8bdc2f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.179758 [ 35675 ] {78f1c09c-708f-4889-adf6-dd260bfe0533} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT INET_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET_NTOA();) 2025.06.18 11:20:31.183008 [ 35675 ] {78f1c09c-708f-4889-adf6-dd260bfe0533} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT INET_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.210579 [ 35675 ] {e027a179-fa54-4849-808f-122065df0226} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv4CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4CIDRToRange();) 2025.06.18 11:20:31.213925 [ 35675 ] {e027a179-fa54-4849-808f-122065df0226} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv4CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.241993 [ 35675 ] {c26f481e-3ad5-4680-b83a-f21cfc8d7ddd} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4NumToString();) 2025.06.18 11:20:31.245439 [ 35675 ] {c26f481e-3ad5-4680-b83a-f21cfc8d7ddd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.275375 [ 35675 ] {8ae78719-7504-47a6-afde-d8feeeb7032b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToStringClassC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4NumToStringClassC();) 2025.06.18 11:20:31.279267 [ 35675 ] {8ae78719-7504-47a6-afde-d8feeeb7032b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToStringClassC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.305347 [ 35675 ] {57789ade-0618-4584-85df-b0f499b61b9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4StringToNum();) 2025.06.18 11:20:31.308754 [ 35675 ] {57789ade-0618-4584-85df-b0f499b61b9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.335814 [ 35675 ] {6a6f2490-3763-4aba-8d69-1e343c0f155c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4StringToNumOrDefault();) 2025.06.18 11:20:31.339678 [ 35675 ] {6a6f2490-3763-4aba-8d69-1e343c0f155c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.367326 [ 35675 ] {dd68f0dc-9e85-48b3-a175-8fec6ca81d8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4StringToNumOrNull();) 2025.06.18 11:20:31.370763 [ 35675 ] {dd68f0dc-9e85-48b3-a175-8fec6ca81d8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.396666 [ 35675 ] {a7ad5be2-47dd-4d7b-b36a-5df7f84ceae9} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 0, should be 1: In scope SELECT IPv4ToIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4ToIPv6();) 2025.06.18 11:20:31.399948 [ 35675 ] {a7ad5be2-47dd-4d7b-b36a-5df7f84ceae9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 0, should be 1: In scope SELECT IPv4ToIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.432001 [ 35675 ] {cfd2c6bd-92be-4288-b6a9-fde0c1ab5c56} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv6CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6CIDRToRange();) 2025.06.18 11:20:31.435328 [ 35675 ] {cfd2c6bd-92be-4288-b6a9-fde0c1ab5c56} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv6CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.462192 [ 35675 ] {5565f402-41a5-4319-a064-a3b7edb6a33c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv6NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6NumToString();) 2025.06.18 11:20:31.465715 [ 35675 ] {5565f402-41a5-4319-a064-a3b7edb6a33c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv6NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.490460 [ 35675 ] {783d9617-61eb-4b53-b891-9a3aab59eda2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6StringToNum();) 2025.06.18 11:20:31.493767 [ 35675 ] {783d9617-61eb-4b53-b891-9a3aab59eda2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.519402 [ 35675 ] {d71dd801-d029-49d4-94a9-931895e5f2d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6StringToNumOrDefault();) 2025.06.18 11:20:31.522751 [ 35675 ] {d71dd801-d029-49d4-94a9-931895e5f2d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.548540 [ 35675 ] {13b3ca6e-f35f-4b55-a35c-db8435832c0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6StringToNumOrNull();) 2025.06.18 11:20:31.551794 [ 35675 ] {13b3ca6e-f35f-4b55-a35c-db8435832c0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.578264 [ 35675 ] {91714181-29c8-4799-aea5-f4b5f0c5b946} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 0, should be 1: In scope SELECT JSONAllPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONAllPaths();) 2025.06.18 11:20:31.581598 [ 35675 ] {91714181-29c8-4799-aea5-f4b5f0c5b946} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 0, should be 1: In scope SELECT JSONAllPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.607298 [ 35675 ] {7cfd1691-f820-4edc-8a8c-86fbdc18af3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONAllPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONAllPathsWithTypes();) 2025.06.18 11:20:31.610429 [ 35675 ] {7cfd1691-f820-4edc-8a8c-86fbdc18af3a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONAllPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.634908 [ 35675 ] {c66ae71c-8ab5-494a-8fa7-fba36cb6cbc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONArrayLength();) 2025.06.18 11:20:31.638217 [ 35675 ] {c66ae71c-8ab5-494a-8fa7-fba36cb6cbc2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.664402 [ 35675 ] {fe7a8434-6e98-4aaf-8400-b682f8776073} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONDynamicPaths();) 2025.06.18 11:20:31.667624 [ 35675 ] {fe7a8434-6e98-4aaf-8400-b682f8776073} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.694404 [ 35675 ] {e41eac84-63c2-43f4-b8c0-586f3b277de0} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONDynamicPathsWithTypes();) 2025.06.18 11:20:31.697746 [ 35675 ] {e41eac84-63c2-43f4-b8c0-586f3b277de0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.721006 [ 35675 ] {e4ea1fbd-dac9-49fe-bb39-97d77c9efb19} executeQuery: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtract();) 2025.06.18 11:20:31.724092 [ 35675 ] {e4ea1fbd-dac9-49fe-bb39-97d77c9efb19} TCPHandler: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.750382 [ 35675 ] {ca0aa700-41d5-4071-a9d8-e3a18bb2c27a} executeQuery: Code: 42. DB::Exception: Function JSONExtractArrayRaw requires at least one argument: In scope SELECT JSONExtractArrayRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractArrayRaw();) 2025.06.18 11:20:31.753572 [ 35675 ] {ca0aa700-41d5-4071-a9d8-e3a18bb2c27a} TCPHandler: Code: 42. DB::Exception: Function JSONExtractArrayRaw requires at least one argument: In scope SELECT JSONExtractArrayRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.780867 [ 35675 ] {106d5b7f-3e9c-4d03-aa19-fe3c65a2faf3} executeQuery: Code: 42. DB::Exception: Function JSONExtractBool requires at least one argument: In scope SELECT JSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractBool();) 2025.06.18 11:20:31.784053 [ 35675 ] {106d5b7f-3e9c-4d03-aa19-fe3c65a2faf3} TCPHandler: Code: 42. DB::Exception: Function JSONExtractBool requires at least one argument: In scope SELECT JSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.812908 [ 35675 ] {f823a604-333a-4ed3-8756-6ee2913f5be6} executeQuery: Code: 42. DB::Exception: Function JSONExtractFloat requires at least one argument: In scope SELECT JSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractFloat();) 2025.06.18 11:20:31.816503 [ 35675 ] {f823a604-333a-4ed3-8756-6ee2913f5be6} TCPHandler: Code: 42. DB::Exception: Function JSONExtractFloat requires at least one argument: In scope SELECT JSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.847019 [ 35675 ] {4e71618d-820b-4f20-869d-2ed6fc79468f} executeQuery: Code: 42. DB::Exception: Function JSONExtractInt requires at least one argument: In scope SELECT JSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractInt();) 2025.06.18 11:20:31.850957 [ 35675 ] {4e71618d-820b-4f20-869d-2ed6fc79468f} TCPHandler: Code: 42. DB::Exception: Function JSONExtractInt requires at least one argument: In scope SELECT JSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.880151 [ 35675 ] {b5f612e6-72e7-4e0d-ac80-b8112ee72f49} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeys requires at least one argument: In scope SELECT JSONExtractKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractKeys();) 2025.06.18 11:20:31.883813 [ 35675 ] {b5f612e6-72e7-4e0d-ac80-b8112ee72f49} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeys requires at least one argument: In scope SELECT JSONExtractKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.910930 [ 35675 ] {a514833a-10a6-469f-8091-a5d06f50a336} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractKeysAndValues();) 2025.06.18 11:20:31.914591 [ 35675 ] {a514833a-10a6-469f-8091-a5d06f50a336} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.944767 [ 35675 ] {5db72add-0c9c-408a-b102-9cc4a757cf30} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValuesRaw requires at least one argument: In scope SELECT JSONExtractKeysAndValuesRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractKeysAndValuesRaw();) 2025.06.18 11:20:31.948249 [ 35675 ] {5db72add-0c9c-408a-b102-9cc4a757cf30} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValuesRaw requires at least one argument: In scope SELECT JSONExtractKeysAndValuesRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:31.975733 [ 35675 ] {f937d69c-f8c9-4e06-b7e0-6764f2c97963} executeQuery: Code: 42. DB::Exception: Function JSONExtractRaw requires at least one argument: In scope SELECT JSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractRaw();) 2025.06.18 11:20:31.978993 [ 35675 ] {f937d69c-f8c9-4e06-b7e0-6764f2c97963} TCPHandler: Code: 42. DB::Exception: Function JSONExtractRaw requires at least one argument: In scope SELECT JSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.004706 [ 35675 ] {41a739d2-8fcd-4aab-abf0-c7de0c6cd2a2} executeQuery: Code: 42. DB::Exception: Function JSONExtractString requires at least one argument: In scope SELECT JSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractString();) 2025.06.18 11:20:32.007966 [ 35675 ] {41a739d2-8fcd-4aab-abf0-c7de0c6cd2a2} TCPHandler: Code: 42. DB::Exception: Function JSONExtractString requires at least one argument: In scope SELECT JSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.027962 [ 35675 ] {9e1c0680-345a-44b7-9e49-04e97a247d83} executeQuery: Code: 42. DB::Exception: Function JSONExtractUInt requires at least one argument: In scope SELECT JSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractUInt();) 2025.06.18 11:20:32.031149 [ 35675 ] {9e1c0680-345a-44b7-9e49-04e97a247d83} TCPHandler: Code: 42. DB::Exception: Function JSONExtractUInt requires at least one argument: In scope SELECT JSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.055914 [ 35675 ] {fb4b329f-6fd1-4380-8d96-36fe41cc8ee4} executeQuery: Code: 42. DB::Exception: Function JSONHas requires at least one argument: In scope SELECT JSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONHas();) 2025.06.18 11:20:32.059249 [ 35675 ] {fb4b329f-6fd1-4380-8d96-36fe41cc8ee4} TCPHandler: Code: 42. DB::Exception: Function JSONHas requires at least one argument: In scope SELECT JSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.085152 [ 35675 ] {ae97b870-bacf-4d6f-b3d4-8cc17c762d75} executeQuery: Code: 42. DB::Exception: Function JSONKey requires at least one argument: In scope SELECT JSONKey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONKey();) 2025.06.18 11:20:32.088331 [ 35675 ] {ae97b870-bacf-4d6f-b3d4-8cc17c762d75} TCPHandler: Code: 42. DB::Exception: Function JSONKey requires at least one argument: In scope SELECT JSONKey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.113391 [ 35675 ] {fb062c29-a577-4b97-acef-8a1300e58f40} executeQuery: Code: 42. DB::Exception: Function JSONLength requires at least one argument: In scope SELECT JSONLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONLength();) 2025.06.18 11:20:32.116710 [ 35675 ] {fb062c29-a577-4b97-acef-8a1300e58f40} TCPHandler: Code: 42. DB::Exception: Function JSONLength requires at least one argument: In scope SELECT JSONLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.142745 [ 35675 ] {02ee4373-0b15-4a92-8045-773d69475106} executeQuery: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT JSONMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONMergePatch();) 2025.06.18 11:20:32.145904 [ 35675 ] {02ee4373-0b15-4a92-8045-773d69475106} TCPHandler: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT JSONMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:32.169140 [ 35675 ] {9c1c5fdc-953d-425e-a0a6-af1b6c914f54} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONSharedDataPaths();) 2025.06.18 11:20:32.172469 [ 35675 ] {9c1c5fdc-953d-425e-a0a6-af1b6c914f54} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.198019 [ 35675 ] {b7d96137-ee5c-4a88-be1b-b0e146fb2e62} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONSharedDataPathsWithTypes();) 2025.06.18 11:20:32.201443 [ 35675 ] {b7d96137-ee5c-4a88-be1b-b0e146fb2e62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.226261 [ 35675 ] {3cee318e-fbfd-4924-a35d-b11db29ee058} executeQuery: Code: 42. DB::Exception: Function JSONType requires at least one argument: In scope SELECT JSONType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONType();) 2025.06.18 11:20:32.229961 [ 35675 ] {3cee318e-fbfd-4924-a35d-b11db29ee058} TCPHandler: Code: 42. DB::Exception: Function JSONType requires at least one argument: In scope SELECT JSONType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.256122 [ 35675 ] {82ec3359-b238-4351-877b-53b30be798a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSON_ARRAY_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_ARRAY_LENGTH();) 2025.06.18 11:20:32.259345 [ 35675 ] {82ec3359-b238-4351-877b-53b30be798a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSON_ARRAY_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.286118 [ 35675 ] {b27f4cc4-c74b-4c37-874f-af7e416d20aa} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_EXISTS();) 2025.06.18 11:20:32.289752 [ 35675 ] {b27f4cc4-c74b-4c37-874f-af7e416d20aa} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:32.316753 [ 35675 ] {78463d04-c1b9-4bbe-bc77-8389db537cb5} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_QUERY();) 2025.06.18 11:20:32.320309 [ 35675 ] {78463d04-c1b9-4bbe-bc77-8389db537cb5} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:32.347796 [ 35675 ] {e39b0d52-31c5-453d-9465-05adcbec7e8f} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_VALUE();) 2025.06.18 11:20:32.351469 [ 35675 ] {e39b0d52-31c5-453d-9465-05adcbec7e8f} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:32.380053 [ 35675 ] {503ee7df-8aee-4f6f-9735-abbbc862be8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT L1Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L1Distance();) 2025.06.18 11:20:32.384288 [ 35675 ] {503ee7df-8aee-4f6f-9735-abbbc862be8b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT L1Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.413501 [ 35675 ] {68b67cd5-5a7b-4c25-8aea-6d0c94c63ca3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT L1Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L1Norm();) 2025.06.18 11:20:32.416770 [ 35675 ] {68b67cd5-5a7b-4c25-8aea-6d0c94c63ca3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT L1Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.441943 [ 35675 ] {a94ed3f2-4af7-472a-b6da-9b4bcef78d97} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT L1Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L1Normalize();) 2025.06.18 11:20:32.445229 [ 35675 ] {a94ed3f2-4af7-472a-b6da-9b4bcef78d97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT L1Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.472506 [ 35675 ] {e27acc2f-5a4e-42cd-9e4d-a5c68c804a94} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT L2Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2Distance();) 2025.06.18 11:20:32.476253 [ 35675 ] {e27acc2f-5a4e-42cd-9e4d-a5c68c804a94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT L2Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.502699 [ 35675 ] {d78c53f8-3ff8-4187-b3c4-c107f86f35aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT L2Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2Norm();) 2025.06.18 11:20:32.506339 [ 35675 ] {d78c53f8-3ff8-4187-b3c4-c107f86f35aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT L2Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.534561 [ 35675 ] {0dd9ab4d-6bfe-46b8-898c-1dc4048608c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT L2Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2Normalize();) 2025.06.18 11:20:32.538439 [ 35675 ] {0dd9ab4d-6bfe-46b8-898c-1dc4048608c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT L2Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.564777 [ 35675 ] {76a4be0f-2083-4b1a-9ac4-15a7cce3541b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT L2SquaredDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2SquaredDistance();) 2025.06.18 11:20:32.568440 [ 35675 ] {76a4be0f-2083-4b1a-9ac4-15a7cce3541b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT L2SquaredDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.601746 [ 35675 ] {2f07a119-ef3c-4ee4-8f5c-b64c8da2492c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT L2SquaredNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2SquaredNorm();) 2025.06.18 11:20:32.605054 [ 35675 ] {2f07a119-ef3c-4ee4-8f5c-b64c8da2492c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT L2SquaredNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.629912 [ 35675 ] {dab1b410-ca8f-4d4c-9440-ebcf9f276e2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT LAST_DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LAST_DAY();) 2025.06.18 11:20:32.633100 [ 35675 ] {dab1b410-ca8f-4d4c-9440-ebcf9f276e2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT LAST_DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.658416 [ 35675 ] {a3d6eb75-b5f4-4ec3-829b-51f0e909c493} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT LinfDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LinfDistance();) 2025.06.18 11:20:32.661570 [ 35675 ] {a3d6eb75-b5f4-4ec3-829b-51f0e909c493} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT LinfDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.689101 [ 35675 ] {5df9e6a5-4b7e-4b7b-86ee-4e8649968e27} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT LinfNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LinfNorm();) 2025.06.18 11:20:32.692423 [ 35675 ] {5df9e6a5-4b7e-4b7b-86ee-4e8649968e27} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT LinfNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.718167 [ 35675 ] {6abd56aa-5369-433d-835d-590f03a63d0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT LinfNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LinfNormalize();) 2025.06.18 11:20:32.721361 [ 35675 ] {6abd56aa-5369-433d-835d-590f03a63d0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT LinfNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.749304 [ 35675 ] {8e3262db-d508-47d1-82da-7c064fa9f38b} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT LpDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LpDistance();) 2025.06.18 11:20:32.752571 [ 35675 ] {8e3262db-d508-47d1-82da-7c064fa9f38b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT LpDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.779072 [ 35675 ] {d3d2e24c-7076-4b3c-be92-2ebbd62066a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT LpNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LpNorm();) 2025.06.18 11:20:32.782310 [ 35675 ] {d3d2e24c-7076-4b3c-be92-2ebbd62066a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT LpNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.809008 [ 35675 ] {81e81d1a-beb3-4f0f-9158-e594060c82d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT LpNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LpNormalize();) 2025.06.18 11:20:32.812484 [ 35675 ] {81e81d1a-beb3-4f0f-9158-e594060c82d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT LpNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.829462 [ 35673 ] {b25e02b6-bb77-4b21-b0ee-119d9cd2039e} executeQuery: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type String: In scope SELECT mapPopulateSeries(['1', '2'], [1, 1]) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35354) (comment: 01318_map_populate_series.sql) (in query: select mapPopulateSeries(['1', '2'], [1, 1]) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionMapPopulateSeries::checkTypes(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001fe90702 5. DB::FunctionMapPopulateSeries::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f7cfbe5 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:32.831496 [ 35673 ] {b25e02b6-bb77-4b21-b0ee-119d9cd2039e} TCPHandler: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type String: In scope SELECT mapPopulateSeries(['1', '2'], [1, 1]) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionMapPopulateSeries::checkTypes(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001fe90702 5. DB::FunctionMapPopulateSeries::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f7cfbe5 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:20:32.838793 [ 35675 ] {7ecaf143-2b42-44e0-81dd-ac7ce3b3f119} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 0, should be 1: In scope SELECT MACNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MACNumToString();) 2025.06.18 11:20:32.841776 [ 35675 ] {7ecaf143-2b42-44e0-81dd-ac7ce3b3f119} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 0, should be 1: In scope SELECT MACNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.865992 [ 35675 ] {595186ec-7c1c-44a3-91d7-3b1e08af4f80} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 0, should be 1: In scope SELECT MACStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MACStringToNum();) 2025.06.18 11:20:32.869466 [ 35675 ] {595186ec-7c1c-44a3-91d7-3b1e08af4f80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 0, should be 1: In scope SELECT MACStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.894011 [ 35675 ] {b501a255-93ec-4689-900c-9de0c8fb16cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 0, should be 1: In scope SELECT MACStringToOUI(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MACStringToOUI();) 2025.06.18 11:20:32.897417 [ 35675 ] {b501a255-93ec-4689-900c-9de0c8fb16cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 0, should be 1: In scope SELECT MACStringToOUI(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.926683 [ 35675 ] {19d370b9-d6ab-4420-be4c-fdda0459ba2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT MAP_FROM_ARRAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MAP_FROM_ARRAYS();) 2025.06.18 11:20:32.930914 [ 35675 ] {19d370b9-d6ab-4420-be4c-fdda0459ba2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT MAP_FROM_ARRAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.959097 [ 35675 ] {294e58f1-08fe-43b3-bd4e-7ae55d0e15b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 0, should be 1: In scope SELECT MD4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MD4();) 2025.06.18 11:20:32.962966 [ 35675 ] {294e58f1-08fe-43b3-bd4e-7ae55d0e15b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 0, should be 1: In scope SELECT MD4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:32.990746 [ 35675 ] {a41f6f88-19d0-48f6-ad18-202400f5fd5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 0, should be 1: In scope SELECT MD5(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MD5();) 2025.06.18 11:20:32.994331 [ 35675 ] {a41f6f88-19d0-48f6-ad18-202400f5fd5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 0, should be 1: In scope SELECT MD5(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.020141 [ 35675 ] {b6d9d456-7c39-41a2-8693-fe05a79c2c94} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT MILLISECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MILLISECOND();) 2025.06.18 11:20:33.023212 [ 35675 ] {b6d9d456-7c39-41a2-8693-fe05a79c2c94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT MILLISECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.049102 [ 35675 ] {4eebb48e-7f9c-4ef1-86a1-28ff74c10094} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT MINUTE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MINUTE();) 2025.06.18 11:20:33.052256 [ 35675 ] {4eebb48e-7f9c-4ef1-86a1-28ff74c10094} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT MINUTE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.075767 [ 35675 ] {447e6033-6162-487d-b5d1-7fbdc7f5d2a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT MONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MONTH();) 2025.06.18 11:20:33.078804 [ 35675 ] {447e6033-6162-487d-b5d1-7fbdc7f5d2a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT MONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.104121 [ 35675 ] {e259cb44-c3bb-4118-a0c7-f9631f609baa} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT OCTET_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT OCTET_LENGTH();) 2025.06.18 11:20:33.107450 [ 35675 ] {e259cb44-c3bb-4118-a0c7-f9631f609baa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT OCTET_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.134247 [ 35675 ] {e09b6362-26ac-489d-b025-018b6301547a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT QUARTER(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT QUARTER();) 2025.06.18 11:20:33.156383 [ 35675 ] {e09b6362-26ac-489d-b025-018b6301547a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT QUARTER(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.182709 [ 35675 ] {b7a64c61-b04a-44bb-b909-b81c3e8d5a0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT REGEXP_EXTRACT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT REGEXP_EXTRACT();) 2025.06.18 11:20:33.185896 [ 35675 ] {b7a64c61-b04a-44bb-b909-b81c3e8d5a0e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT REGEXP_EXTRACT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.210666 [ 35675 ] {cc6bf1a7-0725-476f-94c3-0d4d65302a61} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT REGEXP_MATCHES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT REGEXP_MATCHES();) 2025.06.18 11:20:33.213743 [ 35675 ] {cc6bf1a7-0725-476f-94c3-0d4d65302a61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT REGEXP_MATCHES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.237640 [ 35675 ] {52065506-fedd-4508-b94b-1cb7b0809e50} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT REGEXP_REPLACE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT REGEXP_REPLACE();) 2025.06.18 11:20:33.240832 [ 35675 ] {52065506-fedd-4508-b94b-1cb7b0809e50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT REGEXP_REPLACE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.309107 [ 35675 ] {e565839f-27d0-454c-b929-3350a6dd4101} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT SECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SECOND();) 2025.06.18 11:20:33.312234 [ 35675 ] {e565839f-27d0-454c-b929-3350a6dd4101} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT SECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.334449 [ 35675 ] {a1988701-1383-4b00-bc37-4ff757a23cfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 0, should be 1: In scope SELECT SHA1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA1();) 2025.06.18 11:20:33.337437 [ 35675 ] {a1988701-1383-4b00-bc37-4ff757a23cfc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 0, should be 1: In scope SELECT SHA1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.360010 [ 35675 ] {a9ff752c-2269-41d6-9650-c02f7c139419} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 0, should be 1: In scope SELECT SHA224(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA224();) 2025.06.18 11:20:33.362957 [ 35675 ] {a9ff752c-2269-41d6-9650-c02f7c139419} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 0, should be 1: In scope SELECT SHA224(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.387604 [ 35675 ] {63fa4029-b0a1-4719-b60a-06b5cffab72f} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 0, should be 1: In scope SELECT SHA256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA256();) 2025.06.18 11:20:33.391072 [ 35675 ] {63fa4029-b0a1-4719-b60a-06b5cffab72f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 0, should be 1: In scope SELECT SHA256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.417651 [ 35675 ] {1dffa70b-0793-47f5-ac5a-1da7b3d708ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 0, should be 1: In scope SELECT SHA384(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA384();) 2025.06.18 11:20:33.420908 [ 35675 ] {1dffa70b-0793-47f5-ac5a-1da7b3d708ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 0, should be 1: In scope SELECT SHA384(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.445239 [ 35675 ] {4e75b050-c072-4542-82a0-f735f742c4e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 0, should be 1: In scope SELECT SHA512(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA512();) 2025.06.18 11:20:33.448575 [ 35675 ] {4e75b050-c072-4542-82a0-f735f742c4e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 0, should be 1: In scope SELECT SHA512(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.475509 [ 35675 ] {48fe84ec-23bd-4a99-ac90-e3028f5c6611} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 0, should be 1: In scope SELECT SHA512_256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA512_256();) 2025.06.18 11:20:33.479013 [ 35675 ] {48fe84ec-23bd-4a99-ac90-e3028f5c6611} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 0, should be 1: In scope SELECT SHA512_256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.505081 [ 35675 ] {98a64fa5-3501-40df-ba83-ac838a62e188} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT STD();) 2025.06.18 11:20:33.508237 [ 35675 ] {98a64fa5-3501-40df-ba83-ac838a62e188} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.535118 [ 35675 ] {aa064785-acf9-480e-856e-2b734067b184} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT STDDEV_POP();) 2025.06.18 11:20:33.538705 [ 35675 ] {aa064785-acf9-480e-856e-2b734067b184} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.566770 [ 35675 ] {b58932c5-af4a-41e0-a327-7fb0143a346c} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT STDDEV_SAMP();) 2025.06.18 11:20:33.570616 [ 35675 ] {b58932c5-af4a-41e0-a327-7fb0143a346c} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.598036 [ 35675 ] {9d06bad3-6045-4d12-82b1-611675e9c5e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT SUBSTRING_INDEX(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SUBSTRING_INDEX();) 2025.06.18 11:20:33.601671 [ 35675 ] {9d06bad3-6045-4d12-82b1-611675e9c5e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT SUBSTRING_INDEX(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.620735 [ 35673 ] {e4189199-80cf-40e7-9e4c-a17736029dfa} executeQuery: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2, 3], [1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35354) (comment: 01318_map_populate_series.sql) (in query: select mapPopulateSeries([1, 2, 3], [1, 1]) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x000000001f7d5305 5. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f7cbeee 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:33.622778 [ 35673 ] {e4189199-80cf-40e7-9e4c-a17736029dfa} TCPHandler: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2, 3], [1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x000000001f7d5305 5. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f7cbeee 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:33.629378 [ 35675 ] {9e16d9ee-a178-4224-a154-1aec7f6ce565} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SVG();) 2025.06.18 11:20:33.632288 [ 35675 ] {9e16d9ee-a178-4224-a154-1aec7f6ce565} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.648043 [ 35673 ] {4b430668-9d7c-4a23-8b08-a6469d447b9b} executeQuery: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2], [1, 1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35354) (comment: 01318_map_populate_series.sql) (in query: select mapPopulateSeries([1, 2], [1, 1, 1]) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x000000001f7d5305 5. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f7cbeee 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:33.649894 [ 35673 ] {4b430668-9d7c-4a23-8b08-a6469d447b9b} TCPHandler: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2], [1, 1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x000000001f7d5305 5. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f7cbeee 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:20:33.656795 [ 35675 ] {73205cdf-23bd-4e7c-96f4-fd171938d3f1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TIMESTAMP_DIFF();) 2025.06.18 11:20:33.659571 [ 35675 ] {73205cdf-23bd-4e7c-96f4-fd171938d3f1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.682638 [ 35675 ] {86bfaabc-e122-4336-919c-584ced5f526b} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT TO_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TO_BASE64();) 2025.06.18 11:20:33.685611 [ 35675 ] {86bfaabc-e122-4336-919c-584ced5f526b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT TO_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.708942 [ 35675 ] {a76478e9-2740-4acd-877a-bc3afcbd2c4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT TO_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TO_DAYS();) 2025.06.18 11:20:33.712243 [ 35675 ] {a76478e9-2740-4acd-877a-bc3afcbd2c4c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT TO_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.735805 [ 35675 ] {f5b489aa-10b5-436e-a50d-6e6c35bdea82} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT TO_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TO_UNIXTIME();) 2025.06.18 11:20:33.738947 [ 35675 ] {f5b489aa-10b5-436e-a50d-6e6c35bdea82} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT TO_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.765832 [ 35675 ] {4c58555a-ee16-4cd9-a01f-996e2fbfcbe7} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ULIDStringToDateTime();) 2025.06.18 11:20:33.768994 [ 35675 ] {4c58555a-ee16-4cd9-a01f-996e2fbfcbe7} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.793617 [ 35675 ] {68aa7d3f-6e40-4261-8150-3dbabe28a19f} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 0, should be 1 or 2.: In scope SELECT URLHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT URLHash();) 2025.06.18 11:20:33.797099 [ 35675 ] {68aa7d3f-6e40-4261-8150-3dbabe28a19f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 0, should be 1 or 2.: In scope SELECT URLHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.824707 [ 35675 ] {4382f630-681b-40ee-8772-2daab4630e93} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT URLHierarchy();) 2025.06.18 11:20:33.828040 [ 35675 ] {4382f630-681b-40ee-8772-2daab4630e93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.855918 [ 35675 ] {5c455985-ba70-4b46-a450-d3596d7d8bf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLPathHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT URLPathHierarchy();) 2025.06.18 11:20:33.859214 [ 35675 ] {5c455985-ba70-4b46-a450-d3596d7d8bf1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLPathHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:33.976464 [ 35675 ] {b8a303f0-af16-4ac4-b3f9-31e06f716dcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDNumToString();) 2025.06.18 11:20:33.979796 [ 35675 ] {b8a303f0-af16-4ac4-b3f9-31e06f716dcc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.007818 [ 35675 ] {dbb4b2f6-82eb-4858-8326-9a2463396645} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDStringToNum();) 2025.06.18 11:20:34.011078 [ 35675 ] {dbb4b2f6-82eb-4858-8326-9a2463396645} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.037042 [ 35675 ] {975e86a2-917b-422d-8925-cb9b5f8c75e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDToNum();) 2025.06.18 11:20:34.040191 [ 35675 ] {975e86a2-917b-422d-8925-cb9b5f8c75e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.064548 [ 35675 ] {3efdd093-b3a1-4b8a-919f-ddcdd3a3ff20} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDv7ToDateTime();) 2025.06.18 11:20:34.067665 [ 35675 ] {3efdd093-b3a1-4b8a-919f-ddcdd3a3ff20} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.093716 [ 35675 ] {0acb6c0c-e2f3-4466-8355-3481128b8127} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT VAR_POP();) 2025.06.18 11:20:34.097350 [ 35675 ] {0acb6c0c-e2f3-4466-8355-3481128b8127} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.125892 [ 35675 ] {9c54e3ab-437d-410c-8977-3128abafb512} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT VAR_SAMP();) 2025.06.18 11:20:34.129193 [ 35675 ] {9c54e3ab-437d-410c-8977-3128abafb512} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.155373 [ 35675 ] {92d00fb3-f332-45fa-ab85-df3aa4831b4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT YEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YEAR();) 2025.06.18 11:20:34.158648 [ 35675 ] {92d00fb3-f332-45fa-ab85-df3aa4831b4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT YEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.185627 [ 35675 ] {faed8e63-15e8-4c3b-830a-3aade6edbcb7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDToDate();) 2025.06.18 11:20:34.189450 [ 35675 ] {faed8e63-15e8-4c3b-830a-3aade6edbcb7} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.216838 [ 35675 ] {acc1cea7-3eb5-4477-b8b3-b3119932ddcb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDToDate32();) 2025.06.18 11:20:34.220199 [ 35675 ] {acc1cea7-3eb5-4477-b8b3-b3119932ddcb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.250209 [ 35675 ] {3900bdb0-2eba-4f2f-b7b7-514ae3849c5f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime();) 2025.06.18 11:20:34.253915 [ 35675 ] {3900bdb0-2eba-4f2f-b7b7-514ae3849c5f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.281802 [ 35675 ] {c36ca41e-e1b5-42ff-b70e-2796f64cd710} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime64();) 2025.06.18 11:20:34.285386 [ 35675 ] {c36ca41e-e1b5-42ff-b70e-2796f64cd710} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.310389 [ 35675 ] {8cb309c5-8681-4b32-9d5a-b77ab8237a79} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 0, should be 2: In scope SELECT _CAST(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT _CAST();) 2025.06.18 11:20:34.313773 [ 35675 ] {8cb309c5-8681-4b32-9d5a-b77ab8237a79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 0, should be 2: In scope SELECT _CAST(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.337916 [ 35675 ] {047856fb-b311-4573-a0a1-6fdbb8df08cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __actionName();) 2025.06.18 11:20:34.341307 [ 35675 ] {047856fb-b311-4573-a0a1-6fdbb8df08cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.365916 [ 35675 ] {51a63a60-8c2d-4088-ba70-4c47618558da} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitBoolMaskAnd();) 2025.06.18 11:20:34.369370 [ 35675 ] {51a63a60-8c2d-4088-ba70-4c47618558da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.394277 [ 35675 ] {5d634006-30f6-40fb-aa7f-31531ff84509} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitBoolMaskOr();) 2025.06.18 11:20:34.397565 [ 35675 ] {5d634006-30f6-40fb-aa7f-31531ff84509} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.418790 [ 35675 ] {e5144348-a0a1-4528-9608-ae3bc11a231d} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 0, should be 1: In scope SELECT __bitSwapLastTwo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitSwapLastTwo();) 2025.06.18 11:20:34.421933 [ 35675 ] {e5144348-a0a1-4528-9608-ae3bc11a231d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 0, should be 1: In scope SELECT __bitSwapLastTwo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.446063 [ 35675 ] {d7b2a463-8abb-4403-8899-6676b3c1b4db} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 0, should be 1: In scope SELECT __bitWrapperFunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitWrapperFunc();) 2025.06.18 11:20:34.449464 [ 35675 ] {d7b2a463-8abb-4403-8899-6676b3c1b4db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 0, should be 1: In scope SELECT __bitWrapperFunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.474838 [ 35675 ] {581de3a2-27c6-484f-98f2-ccc9113e1042} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __getScalar();) 2025.06.18 11:20:34.478594 [ 35675 ] {581de3a2-27c6-484f-98f2-ccc9113e1042} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.505373 [ 35675 ] {c7b060d4-adcb-40fb-97c8-b18d5428f980} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 0, should be 1: In scope SELECT __scalarSubqueryResult(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __scalarSubqueryResult();) 2025.06.18 11:20:34.509118 [ 35675 ] {c7b060d4-adcb-40fb-97c8-b18d5428f980} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 0, should be 1: In scope SELECT __scalarSubqueryResult(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.533759 [ 35675 ] {f62f6aac-9928-4a46-8755-dc3f8c53e53d} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 0, should be 1: In scope SELECT abs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT abs();) 2025.06.18 11:20:34.537061 [ 35675 ] {f62f6aac-9928-4a46-8755-dc3f8c53e53d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 0, should be 1: In scope SELECT abs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.563225 [ 35675 ] {51960291-e3b1-40ef-abaa-f67310a29149} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 0, should be 2: In scope SELECT accurateCast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT accurateCast();) 2025.06.18 11:20:34.566753 [ 35675 ] {51960291-e3b1-40ef-abaa-f67310a29149} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 0, should be 2: In scope SELECT accurateCast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.592924 [ 35675 ] {af0d514e-cb25-434d-8d8c-09b9ae5da4af} executeQuery: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 0: In scope SELECT accurateCastOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT accurateCastOrDefault();) 2025.06.18 11:20:34.596229 [ 35675 ] {af0d514e-cb25-434d-8d8c-09b9ae5da4af} TCPHandler: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 0: In scope SELECT accurateCastOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.620212 [ 35675 ] {ff9e3c9b-be33-4629-868c-1013a023b761} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 0, should be 2: In scope SELECT accurateCastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT accurateCastOrNull();) 2025.06.18 11:20:34.623626 [ 35675 ] {ff9e3c9b-be33-4629-868c-1013a023b761} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 0, should be 2: In scope SELECT accurateCastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.650366 [ 35675 ] {f847e77f-9cab-4ab9-b703-f3b5e52786e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 0, should be 1: In scope SELECT acos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT acos();) 2025.06.18 11:20:34.653831 [ 35675 ] {f847e77f-9cab-4ab9-b703-f3b5e52786e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 0, should be 1: In scope SELECT acos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.680458 [ 35675 ] {d3cfb220-0b15-413b-9e3f-f10dd68c5360} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 0, should be 1: In scope SELECT acosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT acosh();) 2025.06.18 11:20:34.684101 [ 35675 ] {d3cfb220-0b15-413b-9e3f-f10dd68c5360} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 0, should be 1: In scope SELECT acosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.708785 [ 35675 ] {8ec68f60-41ae-4b55-a80d-833dc4d9624f} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 0, should be 2: In scope SELECT addDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addDate();) 2025.06.18 11:20:34.711947 [ 35675 ] {8ec68f60-41ae-4b55-a80d-833dc4d9624f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 0, should be 2: In scope SELECT addDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.735550 [ 35675 ] {dbb44f71-0aab-4c42-845b-ba8852c35246} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 0, should be 2 or 3: In scope SELECT addDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addDays();) 2025.06.18 11:20:34.738745 [ 35675 ] {dbb44f71-0aab-4c42-845b-ba8852c35246} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 0, should be 2 or 3: In scope SELECT addDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.764271 [ 35675 ] {b9d4b2d1-1658-4573-9ffe-5d3c0dd48a02} executeQuery: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 0, should be 2 or 3: In scope SELECT addHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addHours();) 2025.06.18 11:20:34.767600 [ 35675 ] {b9d4b2d1-1658-4573-9ffe-5d3c0dd48a02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 0, should be 2 or 3: In scope SELECT addHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.790772 [ 35675 ] {6a2bb496-b853-4aaf-98ea-5eb1a6955d57} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 0, should be 2: In scope SELECT addInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addInterval();) 2025.06.18 11:20:34.794264 [ 35675 ] {6a2bb496-b853-4aaf-98ea-5eb1a6955d57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 0, should be 2: In scope SELECT addInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.818285 [ 35675 ] {68338df2-7752-4c4d-ab4d-9de501e13c39} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMicroseconds();) 2025.06.18 11:20:34.821586 [ 35675 ] {68338df2-7752-4c4d-ab4d-9de501e13c39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.845682 [ 35675 ] {76a45c9f-3041-4f3b-ba1d-0e1408e8b648} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMilliseconds();) 2025.06.18 11:20:34.849020 [ 35675 ] {76a45c9f-3041-4f3b-ba1d-0e1408e8b648} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.875887 [ 35675 ] {73aaf087-bbaf-400c-a611-00c0c67c9693} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT addMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMinutes();) 2025.06.18 11:20:34.879174 [ 35675 ] {73aaf087-bbaf-400c-a611-00c0c67c9693} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT addMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.900857 [ 35675 ] {6f2e7f70-56d9-4113-b4ce-08e804269801} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT addMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMonths();) 2025.06.18 11:20:34.903719 [ 35675 ] {6f2e7f70-56d9-4113-b4ce-08e804269801} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT addMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.929577 [ 35675 ] {0da9763e-a0d0-49dc-80dc-603740e3d22c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addNanoseconds();) 2025.06.18 11:20:34.933118 [ 35675 ] {0da9763e-a0d0-49dc-80dc-603740e3d22c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.962560 [ 35675 ] {ed4638a8-fb24-456d-a998-a092bbd05a8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT addQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addQuarters();) 2025.06.18 11:20:34.966455 [ 35675 ] {ed4638a8-fb24-456d-a998-a092bbd05a8f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT addQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:34.996013 [ 35675 ] {cf265800-de5b-4998-95d7-f6c06698fa6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addSeconds();) 2025.06.18 11:20:34.999852 [ 35675 ] {cf265800-de5b-4998-95d7-f6c06698fa6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.027165 [ 35675 ] {50d35847-f887-45ae-9571-2e0996b973e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT addTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addTupleOfIntervals();) 2025.06.18 11:20:35.030366 [ 35675 ] {50d35847-f887-45ae-9571-2e0996b973e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT addTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.056690 [ 35675 ] {06674427-6127-4184-b007-b0411384f1fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT addWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addWeeks();) 2025.06.18 11:20:35.059889 [ 35675 ] {06674427-6127-4184-b007-b0411384f1fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT addWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.085245 [ 35675 ] {c44ef4bc-ca0f-46dd-8050-6b56eec811e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 0, should be 2 or 3: In scope SELECT addYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addYears();) 2025.06.18 11:20:35.088418 [ 35675 ] {c44ef4bc-ca0f-46dd-8050-6b56eec811e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 0, should be 2 or 3: In scope SELECT addYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.112296 [ 35675 ] {089e22d5-4717-456e-859b-b49604de751f} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 0, should be 1: In scope SELECT addressToLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addressToLine();) 2025.06.18 11:20:35.115431 [ 35675 ] {089e22d5-4717-456e-859b-b49604de751f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 0, should be 1: In scope SELECT addressToLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.138023 [ 35675 ] {10e83822-71a7-48af-a120-caaf4bdc3ce8} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 0, should be 1: In scope SELECT addressToLineWithInlines(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addressToLineWithInlines();) 2025.06.18 11:20:35.141168 [ 35675 ] {10e83822-71a7-48af-a120-caaf4bdc3ce8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 0, should be 1: In scope SELECT addressToLineWithInlines(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.166017 [ 35675 ] {6d87adc5-01aa-46bc-8810-638ce878b6e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 0, should be 1: In scope SELECT addressToSymbol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addressToSymbol();) 2025.06.18 11:20:35.169592 [ 35675 ] {6d87adc5-01aa-46bc-8810-638ce878b6e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 0, should be 1: In scope SELECT addressToSymbol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.195412 [ 35675 ] {371005f5-a78b-48ac-8829-0f277263e68e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT aes_decrypt_mysql();) 2025.06.18 11:20:35.198659 [ 35675 ] {371005f5-a78b-48ac-8829-0f277263e68e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.222386 [ 35675 ] {0ed7ff3a-2a51-4633-975f-2782e88f0ca8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT aes_encrypt_mysql();) 2025.06.18 11:20:35.225838 [ 35675 ] {0ed7ff3a-2a51-4633-975f-2782e88f0ca8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.252099 [ 35675 ] {bbfa2904-b423-4d2f-acca-3667cf197122} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT age(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT age();) 2025.06.18 11:20:35.255725 [ 35675 ] {bbfa2904-b423-4d2f-acca-3667cf197122} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT age(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.303665 [ 35675 ] {13a045c5-6ab1-4445-8634-cd0f484c7748} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT aggThrow();) 2025.06.18 11:20:35.308392 [ 35675 ] {13a045c5-6ab1-4445-8634-cd0f484c7748} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.06.18 11:20:35.334375 [ 35675 ] {5e73b49c-60b4-40f4-9594-4e009899e490} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT alphaTokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT alphaTokens();) 2025.06.18 11:20:35.337681 [ 35675 ] {5e73b49c-60b4-40f4-9594-4e009899e490} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT alphaTokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.361609 [ 35675 ] {6464ca73-3dcd-468c-8065-a4b666cfabe7} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT analysisOfVariance();) 2025.06.18 11:20:35.364879 [ 35675 ] {6464ca73-3dcd-468c-8065-a4b666cfabe7} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.389847 [ 35675 ] {0030ed64-f49e-4bbf-8899-cc2ca22765b6} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 0: In scope SELECT and(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT and();) 2025.06.18 11:20:35.393050 [ 35675 ] {0030ed64-f49e-4bbf-8899-cc2ca22765b6} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 0: In scope SELECT and(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:35.419539 [ 35675 ] {32a4a1ea-4926-41e1-bbd0-b351f6e4e576} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anova();) 2025.06.18 11:20:35.422764 [ 35675 ] {32a4a1ea-4926-41e1-bbd0-b351f6e4e576} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.448478 [ 35675 ] {2cf7c830-e363-499f-852a-94763828fc49} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any();) 2025.06.18 11:20:35.451692 [ 35675 ] {2cf7c830-e363-499f-852a-94763828fc49} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.475468 [ 35675 ] {3d584f16-5bb8-40d0-b3c2-4325ee7a8422} executeQuery: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anyHeavy();) 2025.06.18 11:20:35.478671 [ 35675 ] {3d584f16-5bb8-40d0-b3c2-4325ee7a8422} TCPHandler: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.502702 [ 35675 ] {3d00ab1f-ff6d-43ec-9a38-fcf164fa115b} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anyLast();) 2025.06.18 11:20:35.505997 [ 35675 ] {3d00ab1f-ff6d-43ec-9a38-fcf164fa115b} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.531715 [ 35675 ] {b5a672c9-1bec-4a37-b953-fdf744cdc53a} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anyLast_respect_nulls();) 2025.06.18 11:20:35.535488 [ 35675 ] {b5a672c9-1bec-4a37-b953-fdf744cdc53a} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.560640 [ 35675 ] {6ee0911c-ecf7-4aa6-b051-4c02c019188f} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any_respect_nulls();) 2025.06.18 11:20:35.563738 [ 35675 ] {6ee0911c-ecf7-4aa6-b051-4c02c019188f} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.591812 [ 35675 ] {58dfbb6e-1c30-4b21-9408-6feffa4c93c6} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any_value();) 2025.06.18 11:20:35.597312 [ 35675 ] {58dfbb6e-1c30-4b21-9408-6feffa4c93c6} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.625028 [ 35675 ] {b4c2ac9f-f050-4c5a-935a-0254c1f40b3d} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any_value_respect_nulls();) 2025.06.18 11:20:35.628476 [ 35675 ] {b4c2ac9f-f050-4c5a-935a-0254c1f40b3d} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.657329 [ 35675 ] {7675f905-52bd-4e1c-a585-ba70c60270df} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 0, should be 2: In scope SELECT appendTrailingCharIfAbsent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT appendTrailingCharIfAbsent();) 2025.06.18 11:20:35.660895 [ 35675 ] {7675f905-52bd-4e1c-a585-ba70c60270df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 0, should be 2: In scope SELECT appendTrailingCharIfAbsent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.687885 [ 35675 ] {f44714c5-ac64-4115-b551-977f8894e0e0} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT approx_top_count();) 2025.06.18 11:20:35.691286 [ 35675 ] {f44714c5-ac64-4115-b551-977f8894e0e0} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.717774 [ 35675 ] {60188bef-df7a-44e3-8ad3-cb72a9cd5cb8} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT approx_top_k();) 2025.06.18 11:20:35.721428 [ 35675 ] {60188bef-df7a-44e3-8ad3-cb72a9cd5cb8} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.749001 [ 35675 ] {ea1c434b-e5f9-4028-b9ea-1f749dc19645} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT approx_top_sum();) 2025.06.18 11:20:35.752803 [ 35675 ] {ea1c434b-e5f9-4028-b9ea-1f749dc19645} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.778589 [ 35675 ] {1a8a9eee-2506-4abe-9c93-75ec0197ec2b} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT argMax();) 2025.06.18 11:20:35.781923 [ 35675 ] {1a8a9eee-2506-4abe-9c93-75ec0197ec2b} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.807481 [ 35675 ] {ba2fba91-8f7c-46af-9e3b-ade477df5ea2} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT argMin();) 2025.06.18 11:20:35.810902 [ 35675 ] {ba2fba91-8f7c-46af-9e3b-ade477df5ea2} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.885114 [ 35675 ] {a6f1f5c1-d6db-416a-9c20-6293ee9d8e39} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 0, should be 2: In scope SELECT arrayAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayAUC();) 2025.06.18 11:20:35.888563 [ 35675 ] {a6f1f5c1-d6db-416a-9c20-6293ee9d8e39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 0, should be 2: In scope SELECT arrayAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.915432 [ 35675 ] {9f81da9e-6c44-4bae-8bc4-fd4c18d86aab} executeQuery: Code: 42. DB::Exception: Function arrayAll needs at least 1 argument, passed 0: In scope SELECT arrayAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayAll();) 2025.06.18 11:20:35.918963 [ 35675 ] {9f81da9e-6c44-4bae-8bc4-fd4c18d86aab} TCPHandler: Code: 42. DB::Exception: Function arrayAll needs at least 1 argument, passed 0: In scope SELECT arrayAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.945943 [ 35675 ] {6ad499a4-ec6d-482a-bd76-2710dab77f1a} executeQuery: Code: 42. DB::Exception: Function arrayAvg needs at least 1 argument, passed 0: In scope SELECT arrayAvg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayAvg();) 2025.06.18 11:20:35.949372 [ 35675 ] {6ad499a4-ec6d-482a-bd76-2710dab77f1a} TCPHandler: Code: 42. DB::Exception: Function arrayAvg needs at least 1 argument, passed 0: In scope SELECT arrayAvg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:35.975371 [ 35675 ] {f1ca7823-813d-48a7-8aa8-440f98258cf3} executeQuery: Code: 42. DB::Exception: Function arrayCompact needs at least 1 argument, passed 0: In scope SELECT arrayCompact(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCompact();) 2025.06.18 11:20:35.978790 [ 35675 ] {f1ca7823-813d-48a7-8aa8-440f98258cf3} TCPHandler: Code: 42. DB::Exception: Function arrayCompact needs at least 1 argument, passed 0: In scope SELECT arrayCompact(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.004456 [ 35675 ] {c52619a8-5788-4e26-9e68-4ab86a75e4a1} executeQuery: Code: 42. DB::Exception: Function arrayConcat requires at least one argument.: In scope SELECT arrayConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayConcat();) 2025.06.18 11:20:36.007676 [ 35675 ] {c52619a8-5788-4e26-9e68-4ab86a75e4a1} TCPHandler: Code: 42. DB::Exception: Function arrayConcat requires at least one argument.: In scope SELECT arrayConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.033939 [ 35675 ] {e8350cd1-cbcf-47f5-8e26-0ef660a448ec} executeQuery: Code: 42. DB::Exception: Function arrayCount needs at least 1 argument, passed 0: In scope SELECT arrayCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCount();) 2025.06.18 11:20:36.037440 [ 35675 ] {e8350cd1-cbcf-47f5-8e26-0ef660a448ec} TCPHandler: Code: 42. DB::Exception: Function arrayCount needs at least 1 argument, passed 0: In scope SELECT arrayCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.062972 [ 35675 ] {7f07eac6-3c3e-486d-a666-b042597d36f5} executeQuery: Code: 42. DB::Exception: Function arrayCumSum needs at least 1 argument, passed 0: In scope SELECT arrayCumSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCumSum();) 2025.06.18 11:20:36.066092 [ 35675 ] {7f07eac6-3c3e-486d-a666-b042597d36f5} TCPHandler: Code: 42. DB::Exception: Function arrayCumSum needs at least 1 argument, passed 0: In scope SELECT arrayCumSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.091752 [ 35675 ] {2b01384a-5fa5-4193-9da5-0afefcde5dde} executeQuery: Code: 42. DB::Exception: Function arrayCumSumNonNegative needs at least 1 argument, passed 0: In scope SELECT arrayCumSumNonNegative(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCumSumNonNegative();) 2025.06.18 11:20:36.094983 [ 35675 ] {2b01384a-5fa5-4193-9da5-0afefcde5dde} TCPHandler: Code: 42. DB::Exception: Function arrayCumSumNonNegative needs at least 1 argument, passed 0: In scope SELECT arrayCumSumNonNegative(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.120741 [ 35675 ] {7ce44b60-f29e-43ac-8325-2102ef64def1} executeQuery: Code: 42. DB::Exception: Function arrayDifference needs at least 1 argument, passed 0: In scope SELECT arrayDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayDifference();) 2025.06.18 11:20:36.123992 [ 35675 ] {7ce44b60-f29e-43ac-8325-2102ef64def1} TCPHandler: Code: 42. DB::Exception: Function arrayDifference needs at least 1 argument, passed 0: In scope SELECT arrayDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.150605 [ 35675 ] {7090f4cd-a9e8-49c5-9717-93f81f7e9f32} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 0, should be 1: In scope SELECT arrayDistinct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayDistinct();) 2025.06.18 11:20:36.154166 [ 35675 ] {7090f4cd-a9e8-49c5-9717-93f81f7e9f32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 0, should be 1: In scope SELECT arrayDistinct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.177188 [ 35675 ] {a8c76630-69a3-43f0-94af-2bf271f2deff} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 0, should be 2: In scope SELECT arrayDotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayDotProduct();) 2025.06.18 11:20:36.180588 [ 35675 ] {a8c76630-69a3-43f0-94af-2bf271f2deff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 0, should be 2: In scope SELECT arrayDotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.206940 [ 35675 ] {c347d723-e0de-4b7f-99ac-14a7f3536cdb} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 0, should be 2: In scope SELECT arrayElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayElement();) 2025.06.18 11:20:36.210491 [ 35675 ] {c347d723-e0de-4b7f-99ac-14a7f3536cdb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 0, should be 2: In scope SELECT arrayElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.238435 [ 35675 ] {24a33234-564b-4de6-b941-c68e18136dcb} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 0, should be 1: In scope SELECT arrayEnumerate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerate();) 2025.06.18 11:20:36.242235 [ 35675 ] {24a33234-564b-4de6-b941-c68e18136dcb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 0, should be 1: In scope SELECT arrayEnumerate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.270648 [ 35675 ] {a90693ca-5661-4a2d-bdbd-fd3f82f2f633} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDense doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDense(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateDense();) 2025.06.18 11:20:36.273925 [ 35675 ] {a90693ca-5661-4a2d-bdbd-fd3f82f2f633} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDense doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDense(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:36.299876 [ 35675 ] {db45ddb9-610f-475d-95e6-4347fdedd0f7} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDenseRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDenseRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateDenseRanked();) 2025.06.18 11:20:36.303245 [ 35675 ] {db45ddb9-610f-475d-95e6-4347fdedd0f7} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDenseRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDenseRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:36.329213 [ 35675 ] {ff5335e4-1a53-4f7d-9f9b-1c38a50412f0} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniq(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateUniq();) 2025.06.18 11:20:36.332548 [ 35675 ] {ff5335e4-1a53-4f7d-9f9b-1c38a50412f0} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniq(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:36.357408 [ 35675 ] {fd327166-6889-4379-9a5d-9cad879df337} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniqRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniqRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateUniqRanked();) 2025.06.18 11:20:36.360771 [ 35675 ] {fd327166-6889-4379-9a5d-9cad879df337} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniqRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniqRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:36.387697 [ 35675 ] {00ae0142-f02a-4c02-bc10-f19682ff3bfa} executeQuery: Code: 42. DB::Exception: Function arrayExists needs at least 1 argument, passed 0: In scope SELECT arrayExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayExists();) 2025.06.18 11:20:36.391238 [ 35675 ] {00ae0142-f02a-4c02-bc10-f19682ff3bfa} TCPHandler: Code: 42. DB::Exception: Function arrayExists needs at least 1 argument, passed 0: In scope SELECT arrayExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.417543 [ 35675 ] {5af391a8-37c0-46b2-9f2b-299d06b2d642} executeQuery: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 0: In scope SELECT arrayFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFill();) 2025.06.18 11:20:36.420873 [ 35675 ] {5af391a8-37c0-46b2-9f2b-299d06b2d642} TCPHandler: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 0: In scope SELECT arrayFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.447069 [ 35675 ] {0aaa106c-bded-4665-8d9c-8cc34b4a7591} executeQuery: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 0: In scope SELECT arrayFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFilter();) 2025.06.18 11:20:36.450405 [ 35675 ] {0aaa106c-bded-4665-8d9c-8cc34b4a7591} TCPHandler: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 0: In scope SELECT arrayFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.475898 [ 35675 ] {eafe0d34-1975-47a5-b3ff-9175ce1dadb3} executeQuery: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 0: In scope SELECT arrayFirst(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFirst();) 2025.06.18 11:20:36.480087 [ 35675 ] {eafe0d34-1975-47a5-b3ff-9175ce1dadb3} TCPHandler: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 0: In scope SELECT arrayFirst(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.509682 [ 35675 ] {d69baee8-742c-46ae-9589-a6220abaabf8} executeQuery: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 0: In scope SELECT arrayFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFirstIndex();) 2025.06.18 11:20:36.513619 [ 35675 ] {d69baee8-742c-46ae-9589-a6220abaabf8} TCPHandler: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 0: In scope SELECT arrayFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.544202 [ 35675 ] {51e59232-9115-4002-a9b3-722ec6fbbffe} executeQuery: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayFirstOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFirstOrNull();) 2025.06.18 11:20:36.548298 [ 35675 ] {51e59232-9115-4002-a9b3-722ec6fbbffe} TCPHandler: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayFirstOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.578526 [ 35675 ] {b04aa402-9895-42aa-aa80-c5d4449a3506} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT arrayFlatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFlatten();) 2025.06.18 11:20:36.582218 [ 35675 ] {b04aa402-9895-42aa-aa80-c5d4449a3506} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT arrayFlatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.602589 [ 35675 ] {fb2496e5-d2ca-4e5a-8b82-eee5f0e1799e} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFold();) 2025.06.18 11:20:36.606551 [ 35675 ] {fb2496e5-d2ca-4e5a-8b82-eee5f0e1799e} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:36.633025 [ 35675 ] {d4ecf524-8b89-4366-bc82-28f8e6422381} executeQuery: Code: 42. DB::Exception: Function arrayIntersect requires at least one argument.: In scope SELECT arrayIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayIntersect();) 2025.06.18 11:20:36.636807 [ 35675 ] {d4ecf524-8b89-4366-bc82-28f8e6422381} TCPHandler: Code: 42. DB::Exception: Function arrayIntersect requires at least one argument.: In scope SELECT arrayIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.663823 [ 35675 ] {bfe72911-72d3-40a2-acb0-4d71739cc0fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT arrayJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayJaccardIndex();) 2025.06.18 11:20:36.667518 [ 35675 ] {bfe72911-72d3-40a2-acb0-4d71739cc0fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT arrayJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.695520 [ 35675 ] {c6719272-1dad-4b96-9564-9cb19dfde5aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 0, should be 1: In scope SELECT arrayJoin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayJoin();) 2025.06.18 11:20:36.699834 [ 35675 ] {c6719272-1dad-4b96-9564-9cb19dfde5aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 0, should be 1: In scope SELECT arrayJoin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.733268 [ 35675 ] {c37f3a6d-3a38-4357-9f72-e5f4628cdf93} executeQuery: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 0: In scope SELECT arrayLast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayLast();) 2025.06.18 11:20:36.737610 [ 35675 ] {c37f3a6d-3a38-4357-9f72-e5f4628cdf93} TCPHandler: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 0: In scope SELECT arrayLast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.768086 [ 35675 ] {758ff484-48c5-47b9-8a24-b28a84cd4b7e} executeQuery: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 0: In scope SELECT arrayLastIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayLastIndex();) 2025.06.18 11:20:36.771951 [ 35675 ] {758ff484-48c5-47b9-8a24-b28a84cd4b7e} TCPHandler: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 0: In scope SELECT arrayLastIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.800028 [ 35675 ] {476ba218-55b4-47d4-a66a-9c89038701f1} executeQuery: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayLastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayLastOrNull();) 2025.06.18 11:20:36.803753 [ 35675 ] {476ba218-55b4-47d4-a66a-9c89038701f1} TCPHandler: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayLastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.833091 [ 35675 ] {7c7b353d-37bd-4cee-8012-feaef44e088e} executeQuery: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 0: In scope SELECT arrayMap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayMap();) 2025.06.18 11:20:36.837678 [ 35675 ] {7c7b353d-37bd-4cee-8012-feaef44e088e} TCPHandler: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 0: In scope SELECT arrayMap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.853618 [ 1341 ] {} ExternalDictionariesLoader: Could not check if external dictionary 'ce5afb99-fa8a-44a8-b50a-522cb8da4d3e' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1d98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b1b739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d4a2f0 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347e1530 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347e0263 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e7466 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e721f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:20:36.867271 [ 35675 ] {4fc0419e-cfae-494d-9092-412444e62280} executeQuery: Code: 42. DB::Exception: Function arrayMax needs at least 1 argument, passed 0: In scope SELECT arrayMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayMax();) 2025.06.18 11:20:36.871018 [ 35675 ] {4fc0419e-cfae-494d-9092-412444e62280} TCPHandler: Code: 42. DB::Exception: Function arrayMax needs at least 1 argument, passed 0: In scope SELECT arrayMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.898475 [ 35675 ] {f8a20e75-8eff-4878-8dfa-c862cf1b99df} executeQuery: Code: 42. DB::Exception: Function arrayMin needs at least 1 argument, passed 0: In scope SELECT arrayMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayMin();) 2025.06.18 11:20:36.901795 [ 35675 ] {f8a20e75-8eff-4878-8dfa-c862cf1b99df} TCPHandler: Code: 42. DB::Exception: Function arrayMin needs at least 1 argument, passed 0: In scope SELECT arrayMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.928210 [ 35675 ] {8d20a899-741e-46a9-89e8-1f8459926958} executeQuery: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPartialReverseSort();) 2025.06.18 11:20:36.931565 [ 35675 ] {8d20a899-741e-46a9-89e8-1f8459926958} TCPHandler: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.957310 [ 35675 ] {79b8b97d-1a50-4990-81be-bdf192a42180} executeQuery: Code: 42. DB::Exception: Function 'arrayPartialShuffle' needs from 1 to 3 arguments, passed 0.: In scope SELECT arrayPartialShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPartialShuffle();) 2025.06.18 11:20:36.960733 [ 35675 ] {79b8b97d-1a50-4990-81be-bdf192a42180} TCPHandler: Code: 42. DB::Exception: Function 'arrayPartialShuffle' needs from 1 to 3 arguments, passed 0.: In scope SELECT arrayPartialShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:36.986194 [ 35675 ] {0184e85c-5197-43a2-96a8-f187c4552f8e} executeQuery: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPartialSort();) 2025.06.18 11:20:36.989584 [ 35675 ] {0184e85c-5197-43a2-96a8-f187c4552f8e} TCPHandler: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.016365 [ 35675 ] {fc3e7df8-ed73-4d7a-a288-d7094c7adc89} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 0, should be 1: In scope SELECT arrayPopBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPopBack();) 2025.06.18 11:20:37.019709 [ 35675 ] {fc3e7df8-ed73-4d7a-a288-d7094c7adc89} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 0, should be 1: In scope SELECT arrayPopBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.046423 [ 35675 ] {50c183b3-08a8-4027-b45e-8a99c3d9c652} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 0, should be 1: In scope SELECT arrayPopFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPopFront();) 2025.06.18 11:20:37.049670 [ 35675 ] {50c183b3-08a8-4027-b45e-8a99c3d9c652} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 0, should be 1: In scope SELECT arrayPopFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.073687 [ 35675 ] {f46f6996-4a88-420e-b3fa-2257dd5f2a47} executeQuery: Code: 42. DB::Exception: Function arrayProduct needs at least 1 argument, passed 0: In scope SELECT arrayProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayProduct();) 2025.06.18 11:20:37.076731 [ 35675 ] {f46f6996-4a88-420e-b3fa-2257dd5f2a47} TCPHandler: Code: 42. DB::Exception: Function arrayProduct needs at least 1 argument, passed 0: In scope SELECT arrayProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.101908 [ 35675 ] {690c5f58-5cfa-4efd-b670-6d9ecb669512} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 0, should be 2: In scope SELECT arrayPushBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPushBack();) 2025.06.18 11:20:37.105654 [ 35675 ] {690c5f58-5cfa-4efd-b670-6d9ecb669512} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 0, should be 2: In scope SELECT arrayPushBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.131798 [ 35675 ] {48719868-f4fc-4892-bc2e-044302f8b0e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 0, should be 2: In scope SELECT arrayPushFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPushFront();) 2025.06.18 11:20:37.196669 [ 35675 ] {48719868-f4fc-4892-bc2e-044302f8b0e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 0, should be 2: In scope SELECT arrayPushFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.224994 [ 35675 ] {aac7d88d-7acf-4f4e-9319-08085646d01d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 0, should be 2: In scope SELECT arrayRandomSample(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayRandomSample();) 2025.06.18 11:20:37.228329 [ 35675 ] {aac7d88d-7acf-4f4e-9319-08085646d01d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 0, should be 2: In scope SELECT arrayRandomSample(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.253456 [ 35675 ] {13b867d4-b43d-4ea1-8fe7-229fc3236ecb} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 0, should be at least 2.: In scope SELECT arrayReduce(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReduce();) 2025.06.18 11:20:37.256948 [ 35675 ] {13b867d4-b43d-4ea1-8fe7-229fc3236ecb} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 0, should be at least 2.: In scope SELECT arrayReduce(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:37.284530 [ 35675 ] {e693d587-dc32-44c4-a2ac-abf6e0386797} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 0, should be at least 3.: In scope SELECT arrayReduceInRanges(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReduceInRanges();) 2025.06.18 11:20:37.288051 [ 35675 ] {e693d587-dc32-44c4-a2ac-abf6e0386797} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 0, should be at least 3.: In scope SELECT arrayReduceInRanges(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.313638 [ 35675 ] {4c4cc480-0860-460a-8901-026aa55a354b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayResize doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayResize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayResize();) 2025.06.18 11:20:37.316689 [ 35675 ] {4c4cc480-0860-460a-8901-026aa55a354b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayResize doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayResize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.342188 [ 35675 ] {7814e96c-5e87-46f5-8da0-53a82eed6f6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 0, should be 1: In scope SELECT arrayReverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverse();) 2025.06.18 11:20:37.346548 [ 35675 ] {7814e96c-5e87-46f5-8da0-53a82eed6f6d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 0, should be 1: In scope SELECT arrayReverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.373498 [ 35675 ] {a32d8175-f6f2-4ba3-9ee4-c415e8e2b0d7} executeQuery: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 0: In scope SELECT arrayReverseFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverseFill();) 2025.06.18 11:20:37.377237 [ 35675 ] {a32d8175-f6f2-4ba3-9ee4-c415e8e2b0d7} TCPHandler: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 0: In scope SELECT arrayReverseFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.401764 [ 35675 ] {88b2c331-ec4f-416b-b6c3-5be9b5ebb843} executeQuery: Code: 42. DB::Exception: Function arrayReverseSort needs at least 1 argument, passed 0: In scope SELECT arrayReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverseSort();) 2025.06.18 11:20:37.405059 [ 35675 ] {88b2c331-ec4f-416b-b6c3-5be9b5ebb843} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSort needs at least 1 argument, passed 0: In scope SELECT arrayReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.429922 [ 35675 ] {f559be5b-4966-45fe-aad9-12808ea9750c} executeQuery: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 0: In scope SELECT arrayReverseSplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverseSplit();) 2025.06.18 11:20:37.433083 [ 35675 ] {f559be5b-4966-45fe-aad9-12808ea9750c} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 0: In scope SELECT arrayReverseSplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.455901 [ 35675 ] {f798532e-34f1-4cba-b135-f68aba2ffea1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 0, should be 2: In scope SELECT arrayRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayRotateLeft();) 2025.06.18 11:20:37.459070 [ 35675 ] {f798532e-34f1-4cba-b135-f68aba2ffea1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 0, should be 2: In scope SELECT arrayRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.484136 [ 35675 ] {8ffacb77-1500-439b-8633-56811945150d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 0, should be 2: In scope SELECT arrayRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayRotateRight();) 2025.06.18 11:20:37.487312 [ 35675 ] {8ffacb77-1500-439b-8633-56811945150d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 0, should be 2: In scope SELECT arrayRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.512205 [ 35675 ] {5a1cf577-848f-48c9-bee2-403781bff5e5} executeQuery: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShiftLeft();) 2025.06.18 11:20:37.516079 [ 35675 ] {5a1cf577-848f-48c9-bee2-403781bff5e5} TCPHandler: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.551315 [ 35675 ] {719db818-d2be-4c82-b7aa-aef4e357db68} executeQuery: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShiftRight();) 2025.06.18 11:20:37.554833 [ 35675 ] {719db818-d2be-4c82-b7aa-aef4e357db68} TCPHandler: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.579227 [ 35675 ] {be290448-d4e8-4ed1-a542-b8dceebfb448} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShingles();) 2025.06.18 11:20:37.582502 [ 35675 ] {be290448-d4e8-4ed1-a542-b8dceebfb448} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.608372 [ 35675 ] {6cc4d52c-e341-4926-b723-b9604a8fcd7a} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 0.: In scope SELECT arrayShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShuffle();) 2025.06.18 11:20:37.611605 [ 35675 ] {6cc4d52c-e341-4926-b723-b9604a8fcd7a} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 0.: In scope SELECT arrayShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.636329 [ 35675 ] {e30c327a-cf4c-44cd-91df-179a54cc4482} executeQuery: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 0, should be 2 or 3: In scope SELECT arraySlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySlice();) 2025.06.18 11:20:37.639450 [ 35675 ] {e30c327a-cf4c-44cd-91df-179a54cc4482} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 0, should be 2 or 3: In scope SELECT arraySlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.664941 [ 35675 ] {86f65542-3d26-4aca-aba1-7775b33e60b1} executeQuery: Code: 42. DB::Exception: Function arraySort needs at least 1 argument, passed 0: In scope SELECT arraySort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySort();) 2025.06.18 11:20:37.668315 [ 35675 ] {86f65542-3d26-4aca-aba1-7775b33e60b1} TCPHandler: Code: 42. DB::Exception: Function arraySort needs at least 1 argument, passed 0: In scope SELECT arraySort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.694207 [ 35675 ] {76b955c7-02fd-47b5-8aeb-60983eed6c03} executeQuery: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 0: In scope SELECT arraySplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySplit();) 2025.06.18 11:20:37.697932 [ 35675 ] {76b955c7-02fd-47b5-8aeb-60983eed6c03} TCPHandler: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 0: In scope SELECT arraySplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.723229 [ 35675 ] {04ac9a68-9fd0-4850-b54c-8f6a52180ef2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT arrayStringConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayStringConcat();) 2025.06.18 11:20:37.723721 [ 2826 ] {} ExternalDictionariesLoader: Could not update external dictionary 'ce5afb99-fa8a-44a8-b50a-522cb8da4d3e', leaving the previous version, next update is scheduled at 2025-06-18 11:20:42: Code: 60. DB::Exception: Unknown table expression identifier 'test_gadbia1g.dict_invalidate' in scope SELECT dummy, dummy AS two FROM test_gadbia1g.dict_invalidate. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000020b1a791 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:115: DB::ClickHouseDictionarySource::loadAll() @ 0x0000000020b1a515 18. DB::FlatDictionary::loadData() @ 0x0000000020d837d0 19. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000020d830e4 20. std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration const&, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::FlatDictionary::Configuration const&, std::shared_ptr const&) @ 0x0000000020e1048f 21. DB::FlatDictionary::clone() const @ 0x0000000020df5fbe 22. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000347b02b6 23. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000347aba52 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347bafdb 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347baa3f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:20:37.726774 [ 35675 ] {04ac9a68-9fd0-4850-b54c-8f6a52180ef2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT arrayStringConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.752350 [ 35675 ] {d65471fd-7065-4121-9c36-8da4a05d6dcf} executeQuery: Code: 42. DB::Exception: Function arraySum needs at least 1 argument, passed 0: In scope SELECT arraySum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySum();) 2025.06.18 11:20:37.755573 [ 35675 ] {d65471fd-7065-4121-9c36-8da4a05d6dcf} TCPHandler: Code: 42. DB::Exception: Function arraySum needs at least 1 argument, passed 0: In scope SELECT arraySum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.778585 [ 35675 ] {1269c0f2-c0ea-4453-972a-6f6ef87f54d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayUniq(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayUniq();) 2025.06.18 11:20:37.782002 [ 35675 ] {1269c0f2-c0ea-4453-972a-6f6ef87f54d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayUniq(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.807370 [ 35675 ] {3429e99c-d1ba-4365-8122-234c4d9deaa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 0, should be 2: In scope SELECT arrayWithConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayWithConstant();) 2025.06.18 11:20:37.810660 [ 35675 ] {3429e99c-d1ba-4365-8122-234c4d9deaa9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 0, should be 2: In scope SELECT arrayWithConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.836808 [ 35675 ] {662bf9f1-65cd-4741-bccb-577fe36e4581} executeQuery: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayZip();) 2025.06.18 11:20:37.840016 [ 35675 ] {662bf9f1-65cd-4741-bccb-577fe36e4581} TCPHandler: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:37.866262 [ 35675 ] {99f26b18-1154-4223-9e7d-37c1bb4dcf12} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT array_agg();) 2025.06.18 11:20:37.869924 [ 35675 ] {99f26b18-1154-4223-9e7d-37c1bb4dcf12} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.893301 [ 35675 ] {65ed0448-e2ee-4a0c-9002-baa2edf116d6} executeQuery: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT array_concat_agg();) 2025.06.18 11:20:37.897106 [ 35675 ] {65ed0448-e2ee-4a0c-9002-baa2edf116d6} TCPHandler: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:37.925576 [ 35675 ] {7a47e281-9d5f-490f-be2d-8b27b5a1dfa3} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 0, should be 1: In scope SELECT ascii(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ascii();) 2025.06.18 11:20:37.928909 [ 35675 ] {7a47e281-9d5f-490f-be2d-8b27b5a1dfa3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 0, should be 1: In scope SELECT ascii(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.953485 [ 35675 ] {3626b727-8661-416f-919e-e7856de96aad} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 0, should be 1: In scope SELECT asin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT asin();) 2025.06.18 11:20:37.956843 [ 35675 ] {3626b727-8661-416f-919e-e7856de96aad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 0, should be 1: In scope SELECT asin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:37.982685 [ 35675 ] {13a5ae0f-0dc0-4772-b130-efaeacf488e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 0, should be 1: In scope SELECT asinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT asinh();) 2025.06.18 11:20:37.986052 [ 35675 ] {13a5ae0f-0dc0-4772-b130-efaeacf488e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 0, should be 1: In scope SELECT asinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.009907 [ 35675 ] {6c1d5e7a-a28b-4c8b-914f-f67dcf3e6c8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 0, should be 1: In scope SELECT assumeNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT assumeNotNull();) 2025.06.18 11:20:38.013520 [ 35675 ] {6c1d5e7a-a28b-4c8b-914f-f67dcf3e6c8e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 0, should be 1: In scope SELECT assumeNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.034131 [ 35675 ] {b052606c-53b9-4c87-867a-1c670168912b} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 0, should be 1: In scope SELECT atan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT atan();) 2025.06.18 11:20:38.037304 [ 35675 ] {b052606c-53b9-4c87-867a-1c670168912b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 0, should be 1: In scope SELECT atan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.059093 [ 35675 ] {eaf041e8-7d2e-453d-8b4f-a443bc2c5752} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 0, should be 2: In scope SELECT atan2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT atan2();) 2025.06.18 11:20:38.062088 [ 35675 ] {eaf041e8-7d2e-453d-8b4f-a443bc2c5752} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 0, should be 2: In scope SELECT atan2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.085344 [ 35675 ] {c727408f-cdfe-4d34-a5db-fc1dab4fe89b} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 0, should be 1: In scope SELECT atanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT atanh();) 2025.06.18 11:20:38.088399 [ 35675 ] {c727408f-cdfe-4d34-a5db-fc1dab4fe89b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 0, should be 1: In scope SELECT atanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.110625 [ 35675 ] {43d7ceb1-4861-4cd1-bcac-697af5efc9f9} executeQuery: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT avg();) 2025.06.18 11:20:38.113641 [ 35675 ] {43d7ceb1-4861-4cd1-bcac-697af5efc9f9} TCPHandler: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.135294 [ 35675 ] {361acbd4-e62e-40e5-84c4-6f018dd5033e} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT avgWeighted();) 2025.06.18 11:20:38.138488 [ 35675 ] {361acbd4-e62e-40e5-84c4-6f018dd5033e} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.161265 [ 35675 ] {43d9cec0-8b8e-46de-a0d6-1e4671bb6346} executeQuery: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 0.: In scope SELECT bar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bar();) 2025.06.18 11:20:38.164273 [ 35675 ] {43d9cec0-8b8e-46de-a0d6-1e4671bb6346} TCPHandler: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 0.: In scope SELECT bar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.186424 [ 35675 ] {3831c73c-b49e-457a-b2c8-6d02db124808} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 0, should be 1: In scope SELECT base58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base58Decode();) 2025.06.18 11:20:38.189331 [ 35675 ] {3831c73c-b49e-457a-b2c8-6d02db124808} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 0, should be 1: In scope SELECT base58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.213157 [ 35675 ] {8a401f08-7f52-418d-a634-f2bdfcecfcc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 0, should be 1: In scope SELECT base58Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base58Encode();) 2025.06.18 11:20:38.216032 [ 35675 ] {8a401f08-7f52-418d-a634-f2bdfcecfcc9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 0, should be 1: In scope SELECT base58Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.237244 [ 35675 ] {5f582e5d-a20f-47de-b9b1-660a5ee52804} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT base64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64Decode();) 2025.06.18 11:20:38.239908 [ 35675 ] {5f582e5d-a20f-47de-b9b1-660a5ee52804} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT base64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.260362 [ 35675 ] {c669008c-3ce2-46de-bfb0-42f4192d31d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT base64Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64Encode();) 2025.06.18 11:20:38.262904 [ 35675 ] {c669008c-3ce2-46de-bfb0-42f4192d31d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT base64Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.283525 [ 35675 ] {6717727d-b915-4ceb-a3b2-679d79d81726} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64URLDecode();) 2025.06.18 11:20:38.286072 [ 35675 ] {6717727d-b915-4ceb-a3b2-679d79d81726} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.308344 [ 35675 ] {05bc9faa-c44f-47f2-9258-d3b25f522c31} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64URLEncode();) 2025.06.18 11:20:38.311568 [ 35675 ] {05bc9faa-c44f-47f2-9258-d3b25f522c31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.336202 [ 35675 ] {b479dd7a-7f94-401c-8464-421431b555dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 0, should be 1: In scope SELECT basename(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT basename();) 2025.06.18 11:20:38.339375 [ 35675 ] {b479dd7a-7f94-401c-8464-421431b555dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 0, should be 1: In scope SELECT basename(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.363838 [ 35675 ] {64e2dfd9-defe-4374-b773-5a924b136fb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 0, should be 1: In scope SELECT bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bin();) 2025.06.18 11:20:38.366874 [ 35675 ] {64e2dfd9-defe-4374-b773-5a924b136fb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 0, should be 1: In scope SELECT bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.391104 [ 35675 ] {ff6020fd-3978-4d1a-a2df-bdbefe7ecf81} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 0, should be 2: In scope SELECT bitAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitAnd();) 2025.06.18 11:20:38.394255 [ 35675 ] {ff6020fd-3978-4d1a-a2df-bdbefe7ecf81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 0, should be 2: In scope SELECT bitAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.418583 [ 35675 ] {488a344e-7083-44dc-93c9-deeb2eae1f67} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 0, should be 1: In scope SELECT bitCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitCount();) 2025.06.18 11:20:38.421780 [ 35675 ] {488a344e-7083-44dc-93c9-deeb2eae1f67} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 0, should be 1: In scope SELECT bitCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.448674 [ 35675 ] {dd4316db-d5f0-440e-af62-2516c9b0da07} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 0, should be 2: In scope SELECT bitHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitHammingDistance();) 2025.06.18 11:20:38.451891 [ 35675 ] {dd4316db-d5f0-440e-af62-2516c9b0da07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 0, should be 2: In scope SELECT bitHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.475325 [ 35675 ] {9ba4e5bd-9b72-4d74-a118-f638992f2196} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 0, should be 1: In scope SELECT bitNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitNot();) 2025.06.18 11:20:38.478601 [ 35675 ] {9ba4e5bd-9b72-4d74-a118-f638992f2196} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 0, should be 1: In scope SELECT bitNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.504470 [ 35675 ] {0224ac53-62f6-4d04-80d0-4313f9951027} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 0, should be 2: In scope SELECT bitOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitOr();) 2025.06.18 11:20:38.508089 [ 35675 ] {0224ac53-62f6-4d04-80d0-4313f9951027} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 0, should be 2: In scope SELECT bitOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.531214 [ 35675 ] {f9525025-213e-49af-beae-ebc58fed23c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 0, should be 1: In scope SELECT bitPositionsToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitPositionsToArray();) 2025.06.18 11:20:38.534701 [ 35675 ] {f9525025-213e-49af-beae-ebc58fed23c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 0, should be 1: In scope SELECT bitPositionsToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.558297 [ 35675 ] {c674815b-1d6d-4c30-96c5-826c683f20af} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 0, should be 2: In scope SELECT bitRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitRotateLeft();) 2025.06.18 11:20:38.561893 [ 35675 ] {c674815b-1d6d-4c30-96c5-826c683f20af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 0, should be 2: In scope SELECT bitRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.588490 [ 35675 ] {bd065c4c-10f3-47f7-9fe8-22c3c076dcc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 0, should be 2: In scope SELECT bitRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitRotateRight();) 2025.06.18 11:20:38.591690 [ 35675 ] {bd065c4c-10f3-47f7-9fe8-22c3c076dcc1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 0, should be 2: In scope SELECT bitRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.614125 [ 35675 ] {303162ce-081d-405e-bba4-c6aa9054cca3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 0, should be 2: In scope SELECT bitShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitShiftLeft();) 2025.06.18 11:20:38.617281 [ 35675 ] {303162ce-081d-405e-bba4-c6aa9054cca3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 0, should be 2: In scope SELECT bitShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.641544 [ 35675 ] {4cd55480-23d1-4673-8374-59e01f0cff4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 0, should be 2: In scope SELECT bitShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitShiftRight();) 2025.06.18 11:20:38.645237 [ 35675 ] {4cd55480-23d1-4673-8374-59e01f0cff4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 0, should be 2: In scope SELECT bitShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.668228 [ 35675 ] {2e50585c-2471-4872-a399-ff7b6e2bd4f2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitSlice();) 2025.06.18 11:20:38.671941 [ 35675 ] {2e50585c-2471-4872-a399-ff7b6e2bd4f2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.698977 [ 35675 ] {ab9e0a6c-743c-4b00-9be1-33c15850caaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 0, should be 2: In scope SELECT bitTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitTest();) 2025.06.18 11:20:38.702913 [ 35675 ] {ab9e0a6c-743c-4b00-9be1-33c15850caaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 0, should be 2: In scope SELECT bitTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.726387 [ 35675 ] {2570f668-8325-48c1-bee8-6770d7c71980} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAll(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitTestAll();) 2025.06.18 11:20:38.729664 [ 35675 ] {2570f668-8325-48c1-bee8-6770d7c71980} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAll(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:38.756163 [ 1597 ] {2b7937f9-ff34-42d6-aca3-c287fafcc08c} executeQuery: Code: 36. DB::Exception: Dictionary (`invalid_dictionary`) not found: In scope WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0)). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39826) (comment: 02384_analyzer_dict_get_join_get.sql) (in query: WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000034785613 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000034786b96 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000096baf87 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096aae7d 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:38.758261 [ 1597 ] {2b7937f9-ff34-42d6-aca3-c287fafcc08c} TCPHandler: Code: 36. DB::Exception: Dictionary (`invalid_dictionary`) not found: In scope WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000034785613 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000034786b96 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000096baf87 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096aae7d 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:38.758494 [ 35675 ] {a7c1e86c-372c-4c44-8d15-ee9179ee58c8} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAny(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitTestAny();) 2025.06.18 11:20:38.762148 [ 35675 ] {a7c1e86c-372c-4c44-8d15-ee9179ee58c8} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAny(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:38.785029 [ 35675 ] {cf946782-3d59-46c6-8a9d-5ab1abd6c01e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 0, should be 2: In scope SELECT bitXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitXor();) 2025.06.18 11:20:38.788246 [ 35675 ] {cf946782-3d59-46c6-8a9d-5ab1abd6c01e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 0, should be 2: In scope SELECT bitXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.812335 [ 35675 ] {e93e6167-8b8c-4bf9-be69-eced05b6844d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 0, should be 2: In scope SELECT bitmapAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAnd();) 2025.06.18 11:20:38.815480 [ 35675 ] {e93e6167-8b8c-4bf9-be69-eced05b6844d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 0, should be 2: In scope SELECT bitmapAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.842174 [ 35675 ] {e51697e4-9f88-4d79-930d-f6303ffe523a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAndCardinality();) 2025.06.18 11:20:38.845315 [ 35675 ] {e51697e4-9f88-4d79-930d-f6303ffe523a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.879138 [ 35675 ] {b43005fe-ac7c-4e73-912b-13f7fbc36495} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAndnot();) 2025.06.18 11:20:38.883065 [ 35675 ] {b43005fe-ac7c-4e73-912b-13f7fbc36495} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.914741 [ 35675 ] {83c42674-a4d8-4456-bb51-4d9b3a48b60d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnotCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAndnotCardinality();) 2025.06.18 11:20:38.918116 [ 35675 ] {83c42674-a4d8-4456-bb51-4d9b3a48b60d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnotCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.949228 [ 35675 ] {d50d7793-f70c-478a-8f46-3626295893e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 0, should be 1: In scope SELECT bitmapBuild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapBuild();) 2025.06.18 11:20:38.954462 [ 35675 ] {d50d7793-f70c-478a-8f46-3626295893e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 0, should be 1: In scope SELECT bitmapBuild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:38.984137 [ 35675 ] {b2f00052-7a48-40b6-b3aa-297ebe26dea9} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 0, should be 1: In scope SELECT bitmapCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapCardinality();) 2025.06.18 11:20:38.987839 [ 35675 ] {b2f00052-7a48-40b6-b3aa-297ebe26dea9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 0, should be 1: In scope SELECT bitmapCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.015596 [ 35675 ] {39869d84-bacf-4444-a824-279e4dfd56fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 0, should be 2: In scope SELECT bitmapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapContains();) 2025.06.18 11:20:39.019288 [ 35675 ] {39869d84-bacf-4444-a824-279e4dfd56fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 0, should be 2: In scope SELECT bitmapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.049920 [ 35675 ] {abda5c15-3ef2-4feb-94b2-fcc2dfd9b0c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapHasAll();) 2025.06.18 11:20:39.053973 [ 35675 ] {abda5c15-3ef2-4feb-94b2-fcc2dfd9b0c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.084785 [ 35675 ] {dc803089-9851-414c-a58c-13624c4d9f89} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapHasAny();) 2025.06.18 11:20:39.088787 [ 35675 ] {dc803089-9851-414c-a58c-13624c4d9f89} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.118006 [ 35675 ] {ba840383-edd1-48fb-97c2-c19c02570b6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 0, should be 1: In scope SELECT bitmapMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapMax();) 2025.06.18 11:20:39.122493 [ 35675 ] {ba840383-edd1-48fb-97c2-c19c02570b6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 0, should be 1: In scope SELECT bitmapMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.150429 [ 35675 ] {740e28f2-0683-4d6d-8916-9ac956f8d47f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 0, should be 1: In scope SELECT bitmapMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapMin();) 2025.06.18 11:20:39.154453 [ 35675 ] {740e28f2-0683-4d6d-8916-9ac956f8d47f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 0, should be 1: In scope SELECT bitmapMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.182062 [ 35675 ] {493852f6-7656-4285-95c5-013308ee398d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 0, should be 2: In scope SELECT bitmapOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapOr();) 2025.06.18 11:20:39.186152 [ 35675 ] {493852f6-7656-4285-95c5-013308ee398d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 0, should be 2: In scope SELECT bitmapOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.216319 [ 35675 ] {6f811769-8289-4917-860c-7e739464e03d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapOrCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapOrCardinality();) 2025.06.18 11:20:39.220135 [ 35675 ] {6f811769-8289-4917-860c-7e739464e03d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapOrCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.246832 [ 35675 ] {1770719b-72ed-421b-9f63-931b82b7ea51} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapSubsetInRange();) 2025.06.18 11:20:39.250611 [ 35675 ] {1770719b-72ed-421b-9f63-931b82b7ea51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.280269 [ 35675 ] {52d04e7d-b3fd-4424-aee6-e719e181c013} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetLimit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapSubsetLimit();) 2025.06.18 11:20:39.284094 [ 35675 ] {52d04e7d-b3fd-4424-aee6-e719e181c013} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetLimit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.312133 [ 35675 ] {915cf1ce-2f8b-4230-ac16-3431a24e3773} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 0, should be 1: In scope SELECT bitmapToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapToArray();) 2025.06.18 11:20:39.316146 [ 35675 ] {915cf1ce-2f8b-4230-ac16-3431a24e3773} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 0, should be 1: In scope SELECT bitmapToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.347986 [ 35675 ] {46652e17-10f6-4ee0-a2a6-109012a62efa} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 0, should be 3: In scope SELECT bitmapTransform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapTransform();) 2025.06.18 11:20:39.351827 [ 35675 ] {46652e17-10f6-4ee0-a2a6-109012a62efa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 0, should be 3: In scope SELECT bitmapTransform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.379955 [ 35675 ] {ed1f503a-2948-4923-8a65-6eaf8df2762d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 0, should be 2: In scope SELECT bitmapXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapXor();) 2025.06.18 11:20:39.384064 [ 35675 ] {ed1f503a-2948-4923-8a65-6eaf8df2762d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 0, should be 2: In scope SELECT bitmapXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.413133 [ 35675 ] {43fd5077-9c1c-41c4-8360-87a0f3abef0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapXorCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapXorCardinality();) 2025.06.18 11:20:39.416823 [ 35675 ] {43fd5077-9c1c-41c4-8360-87a0f3abef0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapXorCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.446239 [ 35675 ] {fdd9581e-cbb1-4e45-8e53-d43db7ed5567} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 0, should be 1: In scope SELECT bitmaskToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmaskToArray();) 2025.06.18 11:20:39.450394 [ 35675 ] {fdd9581e-cbb1-4e45-8e53-d43db7ed5567} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 0, should be 1: In scope SELECT bitmaskToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.478024 [ 35675 ] {47018e58-b0b7-4b77-9dea-3f8f2cc614ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 0, should be 1: In scope SELECT bitmaskToList(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmaskToList();) 2025.06.18 11:20:39.483028 [ 35675 ] {47018e58-b0b7-4b77-9dea-3f8f2cc614ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 0, should be 1: In scope SELECT bitmaskToList(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.636218 [ 35675 ] {0510ac76-39dc-4d38-8dec-fcef677eac39} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT boundingRatio();) 2025.06.18 11:20:39.639448 [ 35675 ] {0510ac76-39dc-4d38-8dec-fcef677eac39} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.708500 [ 35675 ] {f638a237-6622-411f-87a6-82e2ed4d0a0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT byteHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT byteHammingDistance();) 2025.06.18 11:20:39.711676 [ 35675 ] {f638a237-6622-411f-87a6-82e2ed4d0a0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT byteHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.778008 [ 35675 ] {647fec3d-8b27-4d21-b4be-0fe3d6b00387} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT byteSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT byteSlice();) 2025.06.18 11:20:39.781193 [ 35675 ] {647fec3d-8b27-4d21-b4be-0fe3d6b00387} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT byteSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.804004 [ 35675 ] {da293d29-b135-441c-ae2f-9bcb0df2136d} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT byteSwap();) 2025.06.18 11:20:39.807571 [ 35675 ] {da293d29-b135-441c-ae2f-9bcb0df2136d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.832093 [ 35675 ] {2d0e33f9-c022-4bee-86b0-40d4f4df7285} executeQuery: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpr(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithExpr();) 2025.06.18 11:20:39.835291 [ 35675 ] {2d0e33f9-c022-4bee-86b0-40d4f4df7285} TCPHandler: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpr(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:39.859788 [ 35675 ] {3adc4fb9-5aec-4ed6-93cb-3432752faf89} executeQuery: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpression(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithExpression();) 2025.06.18 11:20:39.863036 [ 35675 ] {3adc4fb9-5aec-4ed6-93cb-3432752faf89} TCPHandler: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpression(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:39.887338 [ 35675 ] {07f0868e-fa73-4a92-a475-92f6120e387c} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithoutExpr();) 2025.06.18 11:20:39.890630 [ 35675 ] {07f0868e-fa73-4a92-a475-92f6120e387c} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.914552 [ 35675 ] {6cb55515-534e-4105-8b3a-88877284e9e5} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithoutExpression();) 2025.06.18 11:20:39.917649 [ 35675 ] {6cb55515-534e-4105-8b3a-88877284e9e5} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:39.941123 [ 1597 ] {5f2a9e34-ca1e-4728-8e58-aaa9e52ecefb} executeQuery: Code: 60. DB::Exception: Table test_ex0xnrk5.invalid_test_table_join does not exist: In scope WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0)). (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39826) (comment: 02384_analyzer_dict_get_join_get.sql) (in query: WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. DB::(anonymous namespace)::getJoin(std::vector> const&, std::shared_ptr) @ 0x000000000840fa2e 8. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000840b0a2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609e3c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:20:39.943757 [ 1597 ] {5f2a9e34-ca1e-4728-8e58-aaa9e52ecefb} TCPHandler: Code: 60. DB::Exception: Table test_ex0xnrk5.invalid_test_table_join does not exist: In scope WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. DB::(anonymous namespace)::getJoin(std::vector> const&, std::shared_ptr) @ 0x000000000840fa2e 8. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000840b0a2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609e3c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:20:39.945920 [ 35675 ] {bddf50c9-c24e-4509-886d-e11244e0cb03} executeQuery: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT catboostEvaluate();) 2025.06.18 11:20:39.949210 [ 35675 ] {bddf50c9-c24e-4509-886d-e11244e0cb03} TCPHandler: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:39.977788 [ 35675 ] {a15831ac-55ff-48f0-8b78-43969c5046ed} executeQuery: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT categoricalInformationValue();) 2025.06.18 11:20:39.981283 [ 35675 ] {a15831ac-55ff-48f0-8b78-43969c5046ed} TCPHandler: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.007161 [ 35675 ] {91074cec-9887-415f-ab76-9f6d9272539a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 0, should be 1: In scope SELECT cbrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cbrt();) 2025.06.18 11:20:40.010438 [ 35675 ] {91074cec-9887-415f-ab76-9f6d9272539a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 0, should be 1: In scope SELECT cbrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.034719 [ 35675 ] {521ee4f8-c277-40f4-9a91-02b1c4c564c5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceil(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ceil();) 2025.06.18 11:20:40.038253 [ 35675 ] {521ee4f8-c277-40f4-9a91-02b1c4c564c5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceil(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.062511 [ 35675 ] {2319da40-0a77-4453-b233-5d9dd26e0d00} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceiling(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ceiling();) 2025.06.18 11:20:40.065944 [ 35675 ] {2319da40-0a77-4453-b233-5d9dd26e0d00} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceiling(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.091008 [ 35675 ] {918c440b-9b3b-4d24-af3e-75ed39ea6fde} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 0, should be 2: In scope SELECT changeDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeDay();) 2025.06.18 11:20:40.095905 [ 35675 ] {918c440b-9b3b-4d24-af3e-75ed39ea6fde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 0, should be 2: In scope SELECT changeDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.124996 [ 35675 ] {10e7d6c4-0eb4-4fc7-8297-1b1737e70e5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 0, should be 2: In scope SELECT changeHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeHour();) 2025.06.18 11:20:40.128987 [ 35675 ] {10e7d6c4-0eb4-4fc7-8297-1b1737e70e5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 0, should be 2: In scope SELECT changeHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.156423 [ 35675 ] {52d21a8d-6009-44b9-a035-94cdc986b493} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 0, should be 2: In scope SELECT changeMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeMinute();) 2025.06.18 11:20:40.160276 [ 35675 ] {52d21a8d-6009-44b9-a035-94cdc986b493} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 0, should be 2: In scope SELECT changeMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.188670 [ 35675 ] {b5276e76-2127-48d2-ad18-8ace73e23ed2} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 0, should be 2: In scope SELECT changeMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeMonth();) 2025.06.18 11:20:40.192374 [ 35675 ] {b5276e76-2127-48d2-ad18-8ace73e23ed2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 0, should be 2: In scope SELECT changeMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.220898 [ 35675 ] {80a94e53-7290-4477-9e4c-d1bb4619124b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 0, should be 2: In scope SELECT changeSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeSecond();) 2025.06.18 11:20:40.224822 [ 35675 ] {80a94e53-7290-4477-9e4c-d1bb4619124b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 0, should be 2: In scope SELECT changeSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.251122 [ 35675 ] {44e2ee20-6b18-4cf2-b4ef-6fdbd97e3f24} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeYear();) 2025.06.18 11:20:40.254585 [ 35675 ] {44e2ee20-6b18-4cf2-b4ef-6fdbd97e3f24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.279703 [ 35675 ] {c600a457-0b40-4a92-9ea4-66f539fe6443} executeQuery: Code: 35. DB::Exception: Number of arguments for function char can't be 0, should be at least 1: In scope SELECT char(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT char();) 2025.06.18 11:20:40.283029 [ 35675 ] {c600a457-0b40-4a92-9ea4-66f539fe6443} TCPHandler: Code: 35. DB::Exception: Number of arguments for function char can't be 0, should be at least 1: In scope SELECT char(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:40.355576 [ 35675 ] {522c6a93-8c2c-4766-add2-991a4248e7aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 0, should be 3: In scope SELECT clamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT clamp();) 2025.06.18 11:20:40.360585 [ 35675 ] {522c6a93-8c2c-4766-add2-991a4248e7aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 0, should be 3: In scope SELECT clamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.535410 [ 35675 ] {e49a12eb-c4ad-4923-a26d-62de6c49f42c} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT concatWithSeparator();) 2025.06.18 11:20:40.539045 [ 35675 ] {e49a12eb-c4ad-4923-a26d-62de6c49f42c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.565704 [ 35675 ] {ca3f09d3-b4ca-4b63-8017-308c6c68dc68} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparatorAssumeInjective doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparatorAssumeInjective(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT concatWithSeparatorAssumeInjective();) 2025.06.18 11:20:40.569204 [ 35675 ] {ca3f09d3-b4ca-4b63-8017-308c6c68dc68} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparatorAssumeInjective doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparatorAssumeInjective(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.593501 [ 35675 ] {a956979f-3b97-4647-b6bd-0e85da254a93} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concat_ws(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT concat_ws();) 2025.06.18 11:20:40.596808 [ 35675 ] {a956979f-3b97-4647-b6bd-0e85da254a93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concat_ws(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.707897 [ 35675 ] {fdf9f56d-fdb1-4564-b3b7-f0a8a66621b6} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT contingency();) 2025.06.18 11:20:40.726018 [ 35675 ] {fdf9f56d-fdb1-4564-b3b7-f0a8a66621b6} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.751081 [ 35675 ] {b6e95ddc-fe54-4992-8ed5-dc8ddb735c39} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 0, should be 3: In scope SELECT convertCharset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT convertCharset();) 2025.06.18 11:20:40.754477 [ 35675 ] {b6e95ddc-fe54-4992-8ed5-dc8ddb735c39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 0, should be 3: In scope SELECT convertCharset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.778373 [ 35675 ] {04d263b9-da35-42df-87ce-1d879dd73708} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT corr();) 2025.06.18 11:20:40.782022 [ 35675 ] {04d263b9-da35-42df-87ce-1d879dd73708} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.860649 [ 35675 ] {509758ab-11b8-46cd-91d5-2904811a0a72} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT corrStable();) 2025.06.18 11:20:40.864029 [ 35675 ] {509758ab-11b8-46cd-91d5-2904811a0a72} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.889647 [ 35675 ] {1a310786-622f-4bd1-9a82-d1287c86170b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 0, should be 1: In scope SELECT cos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cos();) 2025.06.18 11:20:40.893009 [ 35675 ] {1a310786-622f-4bd1-9a82-d1287c86170b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 0, should be 1: In scope SELECT cos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.922663 [ 35675 ] {8f2997b3-c08d-4c18-99b9-70426e0684e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 0, should be 1: In scope SELECT cosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cosh();) 2025.06.18 11:20:40.926020 [ 35675 ] {8f2997b3-c08d-4c18-99b9-70426e0684e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 0, should be 1: In scope SELECT cosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.931311 [ 612 ] {203b6a24-98b8-428d-9c52-7f6fd185fa4d} executeQuery: Code: 269. DB::Exception: Cannot add dependencies for 'test_1qbmddwu.test_dict', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39900) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (in query: CREATE OR REPLACE DICTIONARY test_dict ( id UInt64, value String ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE view)) LAYOUT(FLAT()) LIFETIME(MIN 0 MAX 1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1564: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x00000000339c7f91 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1575: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000339c76cd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348e0293 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1761: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x00000000348c774e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1476: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be81e 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:40.934263 [ 612 ] {203b6a24-98b8-428d-9c52-7f6fd185fa4d} TCPHandler: Code: 269. DB::Exception: Cannot add dependencies for 'test_1qbmddwu.test_dict', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1564: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x00000000339c7f91 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1575: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000339c76cd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348e0293 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1761: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x00000000348c774e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1476: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be81e 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:40.951883 [ 35675 ] {e69f7f22-ec85-4f79-a8b7-d4fb23795b66} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 0, should be 2: In scope SELECT cosineDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cosineDistance();) 2025.06.18 11:20:40.955286 [ 35675 ] {e69f7f22-ec85-4f79-a8b7-d4fb23795b66} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 0, should be 2: In scope SELECT cosineDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:40.958369 [ 612 ] {dd33d121-5c6c-4166-bcfd-c4af350457ce} executeQuery: Code: 269. DB::Exception: Cannot add dependencies for 'test_1qbmddwu.test_dict', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39900) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (in query: REPLACE DICTIONARY test_dict ( id UInt64, value String ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE view)) LAYOUT(FLAT()) LIFETIME(MIN 0 MAX 1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1564: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x00000000339c7f91 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1575: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000339c76cd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348e0293 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1761: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x00000000348c774e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1476: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be81e 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:40.960596 [ 612 ] {dd33d121-5c6c-4166-bcfd-c4af350457ce} TCPHandler: Code: 269. DB::Exception: Cannot add dependencies for 'test_1qbmddwu.test_dict', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2874d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1564: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x00000000339c7f91 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1575: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000339c76cd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348e0293 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1761: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x00000000348c774e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1476: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be81e 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:41.040590 [ 35675 ] {0e9ff898-d060-4899-b44d-4e49a6a213fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 0, should be 1: In scope SELECT countDigits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countDigits();) 2025.06.18 11:20:41.044120 [ 35675 ] {0e9ff898-d060-4899-b44d-4e49a6a213fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 0, should be 1: In scope SELECT countDigits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.069991 [ 35675 ] {a272d3d9-5c99-465d-82e7-ee5ce2ea9686} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 0, should be 2: In scope SELECT countEqual(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countEqual();) 2025.06.18 11:20:41.073508 [ 35675 ] {a272d3d9-5c99-465d-82e7-ee5ce2ea9686} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 0, should be 2: In scope SELECT countEqual(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.100234 [ 35675 ] {eb62a110-bfd2-4a70-9074-ca77d35cba6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 0, should be 2: In scope SELECT countMatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countMatches();) 2025.06.18 11:20:41.103806 [ 35675 ] {eb62a110-bfd2-4a70-9074-ca77d35cba6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 0, should be 2: In scope SELECT countMatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.130468 [ 35675 ] {37415323-229d-4dd3-b1d7-5268bdc326e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT countMatchesCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countMatchesCaseInsensitive();) 2025.06.18 11:20:41.134043 [ 35675 ] {37415323-229d-4dd3-b1d7-5268bdc326e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT countMatchesCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.160370 [ 35675 ] {a8a625a5-d424-4e47-a9fb-117d4ad0b8f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countSubstrings();) 2025.06.18 11:20:41.164436 [ 35675 ] {a8a625a5-d424-4e47-a9fb-117d4ad0b8f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.188533 [ 35675 ] {85240d6d-156a-4a17-943e-e80c460adf72} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countSubstringsCaseInsensitive();) 2025.06.18 11:20:41.191747 [ 35675 ] {85240d6d-156a-4a17-943e-e80c460adf72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.215343 [ 35675 ] {717f089f-4ee5-4de1-b59d-9e4a46d5df69} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countSubstringsCaseInsensitiveUTF8();) 2025.06.18 11:20:41.218351 [ 35675 ] {717f089f-4ee5-4de1-b59d-9e4a46d5df69} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.241364 [ 35675 ] {bf142dd1-7146-432e-859a-21210eb724bf} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarPop();) 2025.06.18 11:20:41.244566 [ 35675 ] {bf142dd1-7146-432e-859a-21210eb724bf} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.318485 [ 35675 ] {cbbcd279-9916-4c19-a1e8-fa6355a14c2b} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarPopStable();) 2025.06.18 11:20:41.321757 [ 35675 ] {cbbcd279-9916-4c19-a1e8-fa6355a14c2b} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.342507 [ 35675 ] {412cbeeb-c6fd-4b60-acc7-ea5e52c070a3} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarSamp();) 2025.06.18 11:20:41.345625 [ 35675 ] {412cbeeb-c6fd-4b60-acc7-ea5e52c070a3} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.419184 [ 35675 ] {e173e7fb-179b-481c-a8f0-213031cd7005} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarSampStable();) 2025.06.18 11:20:41.422381 [ 35675 ] {e173e7fb-179b-481c-a8f0-213031cd7005} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.444700 [ 35675 ] {7bf8f546-8c60-42de-b5cc-57d33ed3f235} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cramersV();) 2025.06.18 11:20:41.447864 [ 35675 ] {7bf8f546-8c60-42de-b5cc-57d33ed3f235} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.463176 [ 612 ] {b85b1964-2486-4b35-99f2-d04e7934359e} executeQuery: Code: 269. DB::Exception: Cannot exchange 'test_1qbmddwu.test_dict' and 'test_1qbmddwu.test_dict_2', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39900) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (in query: EXCHANGE DICTIONARIES test_dict AND test_dict_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1633: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000339c98c8 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1645: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000339c8ca9 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc44c1 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:41.465708 [ 612 ] {b85b1964-2486-4b35-99f2-d04e7934359e} TCPHandler: Code: 269. DB::Exception: Cannot exchange 'test_1qbmddwu.test_dict' and 'test_1qbmddwu.test_dict_2', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1633: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000339c98c8 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1645: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000339c8ca9 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc44c1 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:41.471085 [ 35675 ] {305632b9-d0b5-40d0-891a-6c8102a7edc9} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cramersVBiasCorrected();) 2025.06.18 11:20:41.474269 [ 35675 ] {305632b9-d0b5-40d0-891a-6c8102a7edc9} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.600024 [ 612 ] {5dfd0dcc-0fe0-4396-b74c-c9a626cfa5b3} executeQuery: Code: 269. DB::Exception: Cannot exchange 'test_1qbmddwu.test_dict' and 'test_1qbmddwu.test_dict_2', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39900) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (in query: EXCHANGE DICTIONARIES test_dict AND test_dict_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1633: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000339c98c8 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1645: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000339c8ca9 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc44c1 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:41.602018 [ 612 ] {5dfd0dcc-0fe0-4396-b74c-c9a626cfa5b3} TCPHandler: Code: 269. DB::Exception: Cannot exchange 'test_1qbmddwu.test_dict' and 'test_1qbmddwu.test_dict_2', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1633: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000339c98c8 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1645: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000339c8ca9 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc44c1 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:41.692440 [ 35675 ] {c632d4ba-c344-4bb2-a219-ac929b9ce372} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT currentSchemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT currentSchemas();) 2025.06.18 11:20:41.695868 [ 35675 ] {c632d4ba-c344-4bb2-a219-ac929b9ce372} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT currentSchemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.859593 [ 35675 ] {d52d9ded-9e83-4a5c-a5e0-135734d7aa3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT current_schemas();) 2025.06.18 11:20:41.863067 [ 35675 ] {d52d9ded-9e83-4a5c-a5e0-135734d7aa3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:41.988159 [ 35675 ] {253e128d-4d41-46ed-a588-bf0412090e32} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 0, should be 1: In scope SELECT cutFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutFragment();) 2025.06.18 11:20:41.991568 [ 35675 ] {253e128d-4d41-46ed-a588-bf0412090e32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 0, should be 1: In scope SELECT cutFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.018590 [ 35675 ] {1a892dfd-cbb8-4fec-9cfb-b2fc9aa9caca} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 0, should be 3: In scope SELECT cutIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutIPv6();) 2025.06.18 11:20:42.021925 [ 35675 ] {1a892dfd-cbb8-4fec-9cfb-b2fc9aa9caca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 0, should be 3: In scope SELECT cutIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.032750 [ 35659 ] {80c04413-a7d5-48ed-b264-2b2d4751482c} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT BLAKE3(NULL, NULL);) 2025.06.18 11:20:42.036541 [ 35659 ] {80c04413-a7d5-48ed-b264-2b2d4751482c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.041951 [ 612 ] {3b1a409d-f3c4-4cd5-aa01-1895e0eb1e63} executeQuery: Code: 269. DB::Exception: Cannot rename 'test_1qbmddwu.test_dict_2' to 'test_1qbmddwu.test_dict', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39900) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (in query: RENAME DICTIONARY test_dict_2 to test_dict;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1596: DB::DatabaseCatalog::checkTableCanBeRenamedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000339c8a13 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1608: DB::DatabaseCatalog::checkTableCanBeRenamedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000339c8209 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc49b4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:42.043833 [ 612 ] {3b1a409d-f3c4-4cd5-aa01-1895e0eb1e63} TCPHandler: Code: 269. DB::Exception: Cannot rename 'test_1qbmddwu.test_dict_2' to 'test_1qbmddwu.test_dict', because it will lead to cyclic dependencies: test_1qbmddwu.test_dict -> [test_1qbmddwu.view]; test_1qbmddwu.view -> [test_1qbmddwu.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000339e3217 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1596: DB::DatabaseCatalog::checkTableCanBeRenamedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000339c8a13 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1608: DB::DatabaseCatalog::checkTableCanBeRenamedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000339c8209 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc49b4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:42.049816 [ 35675 ] {2a0a825e-1499-484b-8533-c7f613ed24b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 0, should be 1: In scope SELECT cutQueryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutQueryString();) 2025.06.18 11:20:42.053189 [ 35675 ] {2a0a825e-1499-484b-8533-c7f613ed24b3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 0, should be 1: In scope SELECT cutQueryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.074933 [ 35659 ] {b0b82649-b968-454b-ad70-0a9857ebe8cf} executeQuery: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CAST(NULL, NULL);) 2025.06.18 11:20:42.079881 [ 35659 ] {b0b82649-b968-454b-ad70-0a9857ebe8cf} TCPHandler: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:42.081720 [ 35675 ] {2f0f153c-c3ba-44ee-afc2-1232437d362a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT cutQueryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutQueryStringAndFragment();) 2025.06.18 11:20:42.085511 [ 35675 ] {2f0f153c-c3ba-44ee-afc2-1232437d362a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT cutQueryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.113715 [ 35675 ] {d9b29528-ac52-4065-835c-cebcaf850db3} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomain();) 2025.06.18 11:20:42.117593 [ 35675 ] {d9b29528-ac52-4065-835c-cebcaf850db3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.118341 [ 35659 ] {456f2407-8e5a-4c5f-863a-8cfad9dfa8b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CHARACTER_LENGTH(NULL, NULL);) 2025.06.18 11:20:42.122805 [ 35659 ] {456f2407-8e5a-4c5f-863a-8cfad9dfa8b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.152727 [ 35675 ] {a59af31b-7698-47ef-a214-2fea6b03a2fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustom();) 2025.06.18 11:20:42.156457 [ 35675 ] {a59af31b-7698-47ef-a214-2fea6b03a2fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.161301 [ 35659 ] {8d85e17f-63a3-492b-bae5-537146cef690} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CHAR_LENGTH(NULL, NULL);) 2025.06.18 11:20:42.164948 [ 35659 ] {8d85e17f-63a3-492b-bae5-537146cef690} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.183922 [ 35675 ] {46014247-60f4-4e05-aab2-aebd99176253} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC();) 2025.06.18 11:20:42.187694 [ 35675 ] {46014247-60f4-4e05-aab2-aebd99176253} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.213872 [ 35675 ] {321dee2b-d4be-40ed-9dd5-cbaa63e37ce1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW();) 2025.06.18 11:20:42.217605 [ 35675 ] {321dee2b-d4be-40ed-9dd5-cbaa63e37ce1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.243525 [ 35675 ] {515195a1-077b-4b45-8f1e-543607093b15} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC();) 2025.06.18 11:20:42.247758 [ 35675 ] {515195a1-077b-4b45-8f1e-543607093b15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.275939 [ 35675 ] {d5f16acd-e2ba-4bb9-89eb-d298b14b78dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC();) 2025.06.18 11:20:42.279942 [ 35675 ] {d5f16acd-e2ba-4bb9-89eb-d298b14b78dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.310194 [ 35675 ] {198cde11-14d0-4bf4-94db-3bbe86a5a3ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW();) 2025.06.18 11:20:42.314053 [ 35675 ] {198cde11-14d0-4bf4-94db-3bbe86a5a3ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.334478 [ 35659 ] {45081d6c-ef91-44d8-9455-839ade0c6136} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CRC32(NULL, NULL);) 2025.06.18 11:20:42.337932 [ 35659 ] {45081d6c-ef91-44d8-9455-839ade0c6136} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.343065 [ 35675 ] {5d882e29-9cfb-4a43-a39f-8cc6e560d20a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC();) 2025.06.18 11:20:42.347190 [ 35675 ] {5d882e29-9cfb-4a43-a39f-8cc6e560d20a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.368180 [ 35659 ] {af365ce4-957f-4ebb-b7a8-b59fa7df8146} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CRC32IEEE(NULL, NULL);) 2025.06.18 11:20:42.371661 [ 35659 ] {af365ce4-957f-4ebb-b7a8-b59fa7df8146} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.373688 [ 35675 ] {c2e98314-a9f9-4c23-89c7-ff836eb7eb62} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 0, should be 2: In scope SELECT cutURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutURLParameter();) 2025.06.18 11:20:42.377077 [ 35675 ] {c2e98314-a9f9-4c23-89c7-ff836eb7eb62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 0, should be 2: In scope SELECT cutURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.402619 [ 35675 ] {dc74ed13-026f-40e8-989a-7cc7d881c5d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 0, should be 1: In scope SELECT cutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutWWW();) 2025.06.18 11:20:42.402690 [ 35659 ] {73daaf4c-2b44-4012-8591-93746270857b} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CRC64(NULL, NULL);) 2025.06.18 11:20:42.406120 [ 35675 ] {dc74ed13-026f-40e8-989a-7cc7d881c5d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 0, should be 1: In scope SELECT cutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.406181 [ 35659 ] {73daaf4c-2b44-4012-8591-93746270857b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.432724 [ 35675 ] {2f3ea4e1-5f78-4fa5-88fd-1bc393c587c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 0, should be 2: In scope SELECT damerauLevenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT damerauLevenshteinDistance();) 2025.06.18 11:20:42.436475 [ 35675 ] {2f3ea4e1-5f78-4fa5-88fd-1bc393c587c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 0, should be 2: In scope SELECT damerauLevenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.437599 [ 35659 ] {02fa2f5d-a14e-44d1-9914-257c870b3198} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT DATABASE(NULL, NULL);) 2025.06.18 11:20:42.441092 [ 35659 ] {02fa2f5d-a14e-44d1-9914-257c870b3198} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.462451 [ 35675 ] {da869f57-9e94-4f4f-90de-2d54cc63804d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateDiff();) 2025.06.18 11:20:42.466188 [ 35675 ] {da869f57-9e94-4f4f-90de-2d54cc63804d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.490488 [ 35675 ] {400c969f-3598-4e5a-a22f-36ddcf2ab0b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 0: In scope SELECT dateName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateName();) 2025.06.18 11:20:42.494005 [ 35675 ] {400c969f-3598-4e5a-a22f-36ddcf2ab0b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 0: In scope SELECT dateName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.521370 [ 35675 ] {e5a5a919-6512-49d5-a745-f1bfd84da0de} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTime64ToSnowflake();) 2025.06.18 11:20:42.525063 [ 35675 ] {e5a5a919-6512-49d5-a745-f1bfd84da0de} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.553353 [ 35675 ] {aefb620c-618f-4843-890d-37a653486303} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTime64ToSnowflakeID();) 2025.06.18 11:20:42.557134 [ 35675 ] {aefb620c-618f-4843-890d-37a653486303} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.583676 [ 35675 ] {e09aa3f6-0448-40de-b566-ec0617198bc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTimeToSnowflake();) 2025.06.18 11:20:42.587221 [ 35675 ] {e09aa3f6-0448-40de-b566-ec0617198bc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.613628 [ 35675 ] {e50712a2-dae3-4abc-a954-d6f35480f965} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTimeToSnowflakeID();) 2025.06.18 11:20:42.617185 [ 35675 ] {e50712a2-dae3-4abc-a954-d6f35480f965} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.644234 [ 35675 ] {e7fa45cc-d7aa-4da7-891c-92c99339f232} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT dateTrunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTrunc();) 2025.06.18 11:20:42.647950 [ 35675 ] {e7fa45cc-d7aa-4da7-891c-92c99339f232} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT dateTrunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.674772 [ 35675 ] {165e4379-af28-423b-bcf1-5a72386e4e5f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT date_diff();) 2025.06.18 11:20:42.678479 [ 35675 ] {165e4379-af28-423b-bcf1-5a72386e4e5f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.703844 [ 35675 ] {da317ac4-1a50-48fe-bcc2-5a438ee38b64} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeHTMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeHTMLComponent();) 2025.06.18 11:20:42.707725 [ 35675 ] {da317ac4-1a50-48fe-bcc2-5a438ee38b64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeHTMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.736271 [ 35675 ] {1bcd1e9a-7ad6-4021-bdc7-102721f0fd58} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeURLComponent();) 2025.06.18 11:20:42.740653 [ 35675 ] {1bcd1e9a-7ad6-4021-bdc7-102721f0fd58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.772350 [ 35675 ] {1aaaf51a-5444-4b35-bafc-7cb33bf7e293} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeURLFormComponent();) 2025.06.18 11:20:42.776204 [ 35675 ] {1aaaf51a-5444-4b35-bafc-7cb33bf7e293} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.803367 [ 35675 ] {cd6ef0c6-fabb-463d-8b14-f5c12b73ee09} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeXMLComponent();) 2025.06.18 11:20:42.807170 [ 35675 ] {cd6ef0c6-fabb-463d-8b14-f5c12b73ee09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.836669 [ 35675 ] {30df57e0-9dde-4799-a6ae-862243a9ddb9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT decrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decrypt();) 2025.06.18 11:20:42.840963 [ 35675 ] {30df57e0-9dde-4799-a6ae-862243a9ddb9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT decrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.889978 [ 35659 ] {abd9e261-284a-4903-b104-5399cd4fdee6} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FORMAT_BYTES(NULL, NULL);) 2025.06.18 11:20:42.893328 [ 35659 ] {abd9e261-284a-4903-b104-5399cd4fdee6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.922523 [ 35659 ] {40cbe55b-62a5-4adf-a0a4-4284c1cebe9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FQDN(NULL, NULL);) 2025.06.18 11:20:42.925827 [ 35659 ] {40cbe55b-62a5-4adf-a0a4-4284c1cebe9b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:42.956780 [ 35659 ] {d158f502-fb29-4daa-8c4a-e66441d1e2a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FROM_BASE64(NULL, NULL);) 2025.06.18 11:20:42.980702 [ 35659 ] {d158f502-fb29-4daa-8c4a-e66441d1e2a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.009949 [ 35675 ] {aa5f8733-5bf0-4a95-bc87-44ab04df68fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfArgumentType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT defaultValueOfArgumentType();) 2025.06.18 11:20:43.013834 [ 35675 ] {aa5f8733-5bf0-4a95-bc87-44ab04df68fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfArgumentType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.014156 [ 35659 ] {875eefe3-9232-4bc4-a098-d4af5864b2b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FROM_DAYS(NULL, NULL);) 2025.06.18 11:20:43.018422 [ 35659 ] {875eefe3-9232-4bc4-a098-d4af5864b2b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.040838 [ 35675 ] {95562aae-311e-433d-9bb3-3926487bd4fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT defaultValueOfTypeName();) 2025.06.18 11:20:43.045082 [ 35675 ] {95562aae-311e-433d-9bb3-3926487bd4fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.070969 [ 35675 ] {1a3150d4-9c5f-4d50-aedf-8ddb65cdb5b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 0, should be 1: In scope SELECT degrees(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT degrees();) 2025.06.18 11:20:43.074596 [ 35675 ] {1a3150d4-9c5f-4d50-aedf-8ddb65cdb5b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 0, should be 1: In scope SELECT degrees(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.103130 [ 35675 ] {580395cd-3399-4d0d-af7b-4d9017c2ea84} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT deltaSum();) 2025.06.18 11:20:43.106943 [ 35675 ] {580395cd-3399-4d0d-af7b-4d9017c2ea84} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.133972 [ 35675 ] {161157f7-e611-488e-9aff-7e060a493e08} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT deltaSumTimestamp();) 2025.06.18 11:20:43.138022 [ 35675 ] {161157f7-e611-488e-9aff-7e060a493e08} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.166927 [ 35675 ] {1c95ca54-fb0c-466c-81ba-61ef4fd86b2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 0, should be 1: In scope SELECT demangle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT demangle();) 2025.06.18 11:20:43.170756 [ 35675 ] {1c95ca54-fb0c-466c-81ba-61ef4fd86b2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 0, should be 1: In scope SELECT demangle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.172538 [ 35659 ] {5c2012b1-1dda-4ea6-96fe-9acfd5651d33} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET6_ATON(NULL, NULL);) 2025.06.18 11:20:43.177012 [ 35659 ] {5c2012b1-1dda-4ea6-96fe-9acfd5651d33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.212113 [ 35659 ] {9205a4b8-0fa3-49c2-9bda-c5eeedce3c43} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET6_NTOA(NULL, NULL);) 2025.06.18 11:20:43.217873 [ 35659 ] {9205a4b8-0fa3-49c2-9bda-c5eeedce3c43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.220151 [ 35675 ] {b24f2be1-9c1a-490d-9448-7dd81fd540d5} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT denseRank();) 2025.06.18 11:20:43.226345 [ 35675 ] {b24f2be1-9c1a-490d-9448-7dd81fd540d5} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:20:43.261161 [ 35659 ] {ca6b8ad3-b608-4377-a17c-b45932f5aee5} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET_ATON(NULL, NULL);) 2025.06.18 11:20:43.266432 [ 35659 ] {ca6b8ad3-b608-4377-a17c-b45932f5aee5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.280756 [ 35675 ] {ea9ca62f-7dc5-4080-8a32-506a21416052} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dense_rank();) 2025.06.18 11:20:43.286399 [ 35675 ] {ea9ca62f-7dc5-4080-8a32-506a21416052} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:20:43.304409 [ 35659 ] {46a3f2d4-16cb-4839-b1d3-419a81b341cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET_NTOA(NULL, NULL);) 2025.06.18 11:20:43.308588 [ 35659 ] {46a3f2d4-16cb-4839-b1d3-419a81b341cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.313308 [ 35675 ] {5378890f-2bdc-4425-beaf-b7f727365802} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectCharset();) 2025.06.18 11:20:43.316896 [ 35675 ] {5378890f-2bdc-4425-beaf-b7f727365802} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:20:43.347212 [ 35675 ] {ebfafcb9-1a5b-4fc6-9bb3-67e3e89b0fa6} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectLanguage();) 2025.06.18 11:20:43.352043 [ 35675 ] {ebfafcb9-1a5b-4fc6-9bb3-67e3e89b0fa6} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:20:43.381678 [ 35675 ] {5dcd5418-5c25-4a12-8766-0839e012d8ba} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectLanguageMixed();) 2025.06.18 11:20:43.385762 [ 35675 ] {5dcd5418-5c25-4a12-8766-0839e012d8ba} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:20:43.431865 [ 35675 ] {44da3934-e059-4816-b2bf-41b6fe846a54} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectLanguageUnknown();) 2025.06.18 11:20:43.436544 [ 35675 ] {44da3934-e059-4816-b2bf-41b6fe846a54} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:20:43.446486 [ 35659 ] {ac40f142-bcad-4ae2-8d0a-0b3e2dcd53a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4NumToString(NULL, NULL);) 2025.06.18 11:20:43.459600 [ 35659 ] {ac40f142-bcad-4ae2-8d0a-0b3e2dcd53a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.493373 [ 35675 ] {d4625261-1152-43e9-9314-5290dadb7bcc} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectProgrammingLanguage();) 2025.06.18 11:20:43.498278 [ 35675 ] {d4625261-1152-43e9-9314-5290dadb7bcc} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:20:43.511294 [ 35659 ] {e69d958c-774c-4cae-8159-6b6ed3f9c538} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4NumToStringClassC(NULL, NULL);) 2025.06.18 11:20:43.525189 [ 35659 ] {e69d958c-774c-4cae-8159-6b6ed3f9c538} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.555915 [ 35675 ] {47f880fd-f163-47b3-8733-119f1a634649} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectTonality();) 2025.06.18 11:20:43.561160 [ 35675 ] {47f880fd-f163-47b3-8733-119f1a634649} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:20:43.573292 [ 35659 ] {9eefe622-10a8-4d80-806e-d84c2e32607d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4StringToNum(NULL, NULL);) 2025.06.18 11:20:43.577901 [ 35659 ] {9eefe622-10a8-4d80-806e-d84c2e32607d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.593165 [ 35675 ] {21896f78-6125-4502-8b94-2f930b910986} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGet();) 2025.06.18 11:20:43.596396 [ 35675 ] {21896f78-6125-4502-8b94-2f930b910986} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.613572 [ 35659 ] {bd3d8806-9821-4306-aef2-cb49e4eda584} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL);) 2025.06.18 11:20:43.624213 [ 35675 ] {79b185be-1755-4991-b740-dcdfbe321bde} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetAll();) 2025.06.18 11:20:43.626111 [ 35659 ] {bd3d8806-9821-4306-aef2-cb49e4eda584} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.628931 [ 35675 ] {79b185be-1755-4991-b740-dcdfbe321bde} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.654810 [ 35659 ] {728ba6e7-551b-4152-b50e-fb60b39112e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL);) 2025.06.18 11:20:43.659860 [ 35659 ] {728ba6e7-551b-4152-b50e-fb60b39112e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.675405 [ 35675 ] {54d4a48b-5be9-441a-9d7e-a64b871b9f0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 0, should be 2: In scope SELECT dictGetChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetChildren();) 2025.06.18 11:20:43.681435 [ 35675 ] {54d4a48b-5be9-441a-9d7e-a64b871b9f0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 0, should be 2: In scope SELECT dictGetChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.692784 [ 35659 ] {4efba2e5-f9f3-40ba-8dd2-8ac261e9925a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4ToIPv6(NULL, NULL);) 2025.06.18 11:20:43.700288 [ 35659 ] {4efba2e5-f9f3-40ba-8dd2-8ac261e9925a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.709631 [ 35675 ] {17560b43-1df0-4158-bc4a-2175bc87b3a4} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDate();) 2025.06.18 11:20:43.714421 [ 35675 ] {17560b43-1df0-4158-bc4a-2175bc87b3a4} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.743840 [ 35675 ] {bcc2371f-ba97-40b4-87f7-75ea636f27b9} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDateOrDefault();) 2025.06.18 11:20:43.759816 [ 35675 ] {bcc2371f-ba97-40b4-87f7-75ea636f27b9} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.789731 [ 35675 ] {a1a2d32d-7cad-4dd8-8c35-2e923620b8d6} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDateTime();) 2025.06.18 11:20:43.794797 [ 35675 ] {a1a2d32d-7cad-4dd8-8c35-2e923620b8d6} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.822808 [ 35675 ] {2ccb637b-d4e9-4892-aea5-168e0cbb7a36} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDateTimeOrDefault();) 2025.06.18 11:20:43.827767 [ 35675 ] {2ccb637b-d4e9-4892-aea5-168e0cbb7a36} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.837670 [ 35659 ] {5b90ca19-85c9-42ab-97fc-719d80a29af5} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6NumToString(NULL, NULL);) 2025.06.18 11:20:43.842957 [ 35659 ] {5b90ca19-85c9-42ab-97fc-719d80a29af5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.876028 [ 35675 ] {fc5c6c03-6ffc-4af9-82f1-041f9e4509dc} executeQuery: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 0: In scope SELECT dictGetDescendants(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDescendants();) 2025.06.18 11:20:43.882137 [ 35675 ] {fc5c6c03-6ffc-4af9-82f1-041f9e4509dc} TCPHandler: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 0: In scope SELECT dictGetDescendants(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.884883 [ 35659 ] {aa35a904-b0f1-453a-b86e-643fbdcc5a18} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6StringToNum(NULL, NULL);) 2025.06.18 11:20:43.889942 [ 35659 ] {aa35a904-b0f1-453a-b86e-643fbdcc5a18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.913533 [ 35675 ] {d6716b38-8107-4c81-b6ee-dd0812d780b3} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat32();) 2025.06.18 11:20:43.918286 [ 35675 ] {d6716b38-8107-4c81-b6ee-dd0812d780b3} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.927470 [ 35659 ] {18e216ba-e3c7-4d1b-9939-ede86ac1f530} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL);) 2025.06.18 11:20:43.932396 [ 35659 ] {18e216ba-e3c7-4d1b-9939-ede86ac1f530} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.946281 [ 35675 ] {71f50403-ec13-4cbb-ac1e-6e8ba8d9dbee} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat32OrDefault();) 2025.06.18 11:20:43.951631 [ 35675 ] {71f50403-ec13-4cbb-ac1e-6e8ba8d9dbee} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.976241 [ 35659 ] {7731d187-a672-4558-82b0-e0f03e1ff905} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL);) 2025.06.18 11:20:43.981222 [ 35659 ] {7731d187-a672-4558-82b0-e0f03e1ff905} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:43.991110 [ 35675 ] {2b926cd1-fe03-44d1-b1ac-72a00a1c2fef} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat64();) 2025.06.18 11:20:43.995746 [ 35675 ] {2b926cd1-fe03-44d1-b1ac-72a00a1c2fef} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.022775 [ 35675 ] {57b7c00a-3d14-4069-8c19-391d4f7b1803} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat64OrDefault();) 2025.06.18 11:20:44.027514 [ 35675 ] {57b7c00a-3d14-4069-8c19-391d4f7b1803} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.054527 [ 35659 ] {2b49336f-d535-4eba-ab51-5a7005d61981} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONAllPaths(NULL, NULL);) 2025.06.18 11:20:44.058302 [ 35675 ] {9db801bf-3a73-4634-b652-643732c6a69b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 0, should be 2: In scope SELECT dictGetHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetHierarchy();) 2025.06.18 11:20:44.059291 [ 35659 ] {2b49336f-d535-4eba-ab51-5a7005d61981} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.063063 [ 35675 ] {9db801bf-3a73-4634-b652-643732c6a69b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 0, should be 2: In scope SELECT dictGetHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.088914 [ 35659 ] {6c76675b-d03d-47b7-9af4-581fb011010a} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL);) 2025.06.18 11:20:44.092891 [ 35675 ] {576ed638-2fb6-4710-8815-cd12a48804b2} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv4();) 2025.06.18 11:20:44.093333 [ 35659 ] {6c76675b-d03d-47b7-9af4-581fb011010a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.097706 [ 35675 ] {576ed638-2fb6-4710-8815-cd12a48804b2} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.123769 [ 35675 ] {51baf3ea-2c76-4130-b57f-de8f82471f91} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv4OrDefault();) 2025.06.18 11:20:44.123823 [ 35659 ] {10081f05-118d-48d9-99fe-f1aeffcec0fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONArrayLength(NULL, NULL);) 2025.06.18 11:20:44.127998 [ 35659 ] {10081f05-118d-48d9-99fe-f1aeffcec0fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.128801 [ 35675 ] {51baf3ea-2c76-4130-b57f-de8f82471f91} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.155680 [ 35675 ] {385abd63-3572-44e8-bbfc-8f607d76198a} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv6();) 2025.06.18 11:20:44.155680 [ 35659 ] {0a328a30-1d67-49cb-92ee-2c0e630a5855} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONDynamicPaths(NULL, NULL);) 2025.06.18 11:20:44.160258 [ 35675 ] {385abd63-3572-44e8-bbfc-8f607d76198a} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.160467 [ 35659 ] {0a328a30-1d67-49cb-92ee-2c0e630a5855} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.188120 [ 35675 ] {07d6dced-0622-4a3f-b722-be3ad3cb3841} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv6OrDefault();) 2025.06.18 11:20:44.192401 [ 35659 ] {f9feb255-cbca-43f6-8841-1bd04b85cf10} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL);) 2025.06.18 11:20:44.196065 [ 35659 ] {f9feb255-cbca-43f6-8841-1bd04b85cf10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.196104 [ 35675 ] {07d6dced-0622-4a3f-b722-be3ad3cb3841} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.225672 [ 35659 ] {aa00a0ca-3127-4386-90e4-c282e95c209f} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONExtract(NULL, NULL);) 2025.06.18 11:20:44.225672 [ 35675 ] {a6c9474b-ed2f-4f71-bcf9-5c4a928232d6} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt16();) 2025.06.18 11:20:44.230716 [ 35659 ] {aa00a0ca-3127-4386-90e4-c282e95c209f} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.18 11:20:44.246017 [ 35675 ] {a6c9474b-ed2f-4f71-bcf9-5c4a928232d6} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.276387 [ 35675 ] {ff8b5578-1dd4-4c36-b0b5-dad3001d7a0e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt16OrDefault();) 2025.06.18 11:20:44.281950 [ 35675 ] {ff8b5578-1dd4-4c36-b0b5-dad3001d7a0e} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.312214 [ 35675 ] {0bcde565-44e8-4029-b135-f9c0c4654aff} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt32();) 2025.06.18 11:20:44.317982 [ 35675 ] {0bcde565-44e8-4029-b135-f9c0c4654aff} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.346907 [ 35675 ] {3123f879-05f2-4c39-b244-49279a73d129} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt32OrDefault();) 2025.06.18 11:20:44.352532 [ 35675 ] {3123f879-05f2-4c39-b244-49279a73d129} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.391972 [ 35675 ] {eacc3164-8f9e-4173-b325-8d9885c14f06} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt64();) 2025.06.18 11:20:44.397423 [ 35675 ] {eacc3164-8f9e-4173-b325-8d9885c14f06} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.427969 [ 35675 ] {8f9bd6d3-2da0-4f52-b6fe-708e62141b89} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt64OrDefault();) 2025.06.18 11:20:44.433431 [ 35675 ] {8f9bd6d3-2da0-4f52-b6fe-708e62141b89} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.463710 [ 35675 ] {cccec28c-1274-44f9-9d2d-25e933a4f6f3} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt8();) 2025.06.18 11:20:44.469944 [ 35675 ] {cccec28c-1274-44f9-9d2d-25e933a4f6f3} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.501254 [ 35675 ] {81c04122-98c2-4122-ab2c-1eb1f93092a7} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt8OrDefault();) 2025.06.18 11:20:44.506586 [ 35675 ] {81c04122-98c2-4122-ab2c-1eb1f93092a7} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.534694 [ 35675 ] {c2b943d6-27f9-4e42-8ee1-9652213826e0} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetOrDefault();) 2025.06.18 11:20:44.540167 [ 35675 ] {c2b943d6-27f9-4e42-8ee1-9652213826e0} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.570698 [ 35675 ] {8d834fd0-4ec6-4a72-95fe-0764870efda4} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetOrNull();) 2025.06.18 11:20:44.582559 [ 35675 ] {8d834fd0-4ec6-4a72-95fe-0764870efda4} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.595942 [ 35659 ] {7a24d340-e3b0-481b-9c80-25053b9ee133} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL);) 2025.06.18 11:20:44.600526 [ 35659 ] {7a24d340-e3b0-481b-9c80-25053b9ee133} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.18 11:20:44.619274 [ 35675 ] {b0789f11-14ba-4efa-9395-33c5f312a442} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetString();) 2025.06.18 11:20:44.624746 [ 35675 ] {b0789f11-14ba-4efa-9395-33c5f312a442} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.654400 [ 35675 ] {bfe79ed5-d144-4657-a587-e87369d0c022} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetStringOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetStringOrDefault();) 2025.06.18 11:20:44.659882 [ 35675 ] {bfe79ed5-d144-4657-a587-e87369d0c022} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetStringOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.690092 [ 35675 ] {f0e730bd-9b2c-4aa4-9fae-58617b59adf5} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt16();) 2025.06.18 11:20:44.695567 [ 35675 ] {f0e730bd-9b2c-4aa4-9fae-58617b59adf5} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.724161 [ 35675 ] {82f79012-a8a3-4b50-b2a7-b917836c56d5} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt16OrDefault();) 2025.06.18 11:20:44.729570 [ 35675 ] {82f79012-a8a3-4b50-b2a7-b917836c56d5} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.758210 [ 35675 ] {3b37f284-1150-4b46-bf33-3d3f4d69b08e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt32();) 2025.06.18 11:20:44.763607 [ 35675 ] {3b37f284-1150-4b46-bf33-3d3f4d69b08e} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.794241 [ 35675 ] {f9e67d9b-c701-40db-ac42-b3d444d61682} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt32OrDefault();) 2025.06.18 11:20:44.800121 [ 35675 ] {f9e67d9b-c701-40db-ac42-b3d444d61682} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.831460 [ 35675 ] {62792f83-8c8e-45c4-ad6a-1b83e37d4bd2} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt64();) 2025.06.18 11:20:44.837167 [ 35675 ] {62792f83-8c8e-45c4-ad6a-1b83e37d4bd2} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.866987 [ 35675 ] {0484b109-64c9-4446-8a99-e2c7d89d0f61} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt64OrDefault();) 2025.06.18 11:20:44.871633 [ 35675 ] {0484b109-64c9-4446-8a99-e2c7d89d0f61} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.896181 [ 35675 ] {2a32147b-fbfb-4e70-bda4-0c3ac8a3c7ca} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt8();) 2025.06.18 11:20:44.900853 [ 35675 ] {2a32147b-fbfb-4e70-bda4-0c3ac8a3c7ca} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.926608 [ 35675 ] {c13847bb-e071-4c79-8e93-35ebfaa42237} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt8OrDefault();) 2025.06.18 11:20:44.932045 [ 35675 ] {c13847bb-e071-4c79-8e93-35ebfaa42237} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:44.966680 [ 35675 ] {ad90caab-ff56-436b-bcb6-e40e5eb621fd} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUUID();) 2025.06.18 11:20:44.975486 [ 35675 ] {ad90caab-ff56-436b-bcb6-e40e5eb621fd} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.002398 [ 35675 ] {8e9ccba4-995f-418e-a1af-6b5bbd0d282b} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUUIDOrDefault();) 2025.06.18 11:20:45.007903 [ 35675 ] {8e9ccba4-995f-418e-a1af-6b5bbd0d282b} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.041515 [ 35675 ] {70e991ef-f659-4b5e-bf06-97431b95b31a} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictHas();) 2025.06.18 11:20:45.046985 [ 35675 ] {70e991ef-f659-4b5e-bf06-97431b95b31a} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.072817 [ 35675 ] {fe40d516-6d7c-47e7-a50f-aef953508e28} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 0, should be 3: In scope SELECT dictIsIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictIsIn();) 2025.06.18 11:20:45.080212 [ 35675 ] {fe40d516-6d7c-47e7-a50f-aef953508e28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 0, should be 3: In scope SELECT dictIsIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.150718 [ 35675 ] {f2480e8e-aa60-41f1-97f2-421a9e78dc60} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceL1();) 2025.06.18 11:20:45.154626 [ 35675 ] {f2480e8e-aa60-41f1-97f2-421a9e78dc60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.183310 [ 35675 ] {8ccb355e-888b-4833-9905-19892517ea4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceL2();) 2025.06.18 11:20:45.188345 [ 35675 ] {8ccb355e-888b-4833-9905-19892517ea4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.204972 [ 35659 ] {f91381f8-0b75-47b2-83ea-42eed8843f43} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONSharedDataPaths(NULL, NULL);) 2025.06.18 11:20:45.210052 [ 35659 ] {f91381f8-0b75-47b2-83ea-42eed8843f43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.215257 [ 35675 ] {836029a7-bfd9-406d-9c1a-f4350fffad96} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT distanceL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceL2Squared();) 2025.06.18 11:20:45.219909 [ 35675 ] {836029a7-bfd9-406d-9c1a-f4350fffad96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT distanceL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.244659 [ 35659 ] {e9adbebc-3bcb-4397-a0f1-ce5c8ae5e252} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL);) 2025.06.18 11:20:45.249576 [ 35659 ] {e9adbebc-3bcb-4397-a0f1-ce5c8ae5e252} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.254289 [ 35675 ] {56145f5c-e613-4ad4-bb44-ec1487c5c6af} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT distanceLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceLinf();) 2025.06.18 11:20:45.261740 [ 35675 ] {56145f5c-e613-4ad4-bb44-ec1487c5c6af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT distanceLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.290374 [ 35675 ] {c9e987c1-ecbc-4591-ab3a-a58b996daf57} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT distanceLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceLp();) 2025.06.18 11:20:45.295669 [ 35675 ] {c9e987c1-ecbc-4591-ab3a-a58b996daf57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT distanceLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.325564 [ 35675 ] {6468536b-4492-4e13-ad96-592acaa35784} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 0, should be 2: In scope SELECT divide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT divide();) 2025.06.18 11:20:45.330520 [ 35675 ] {6468536b-4492-4e13-ad96-592acaa35784} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 0, should be 2: In scope SELECT divide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.356436 [ 35675 ] {0cd89eb1-0fce-4265-8521-3bf1b98998f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT divideDecimal();) 2025.06.18 11:20:45.356787 [ 35659 ] {5748f547-e16a-4937-af55-b4728535978d} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL);) 2025.06.18 11:20:45.361223 [ 35675 ] {0cd89eb1-0fce-4265-8521-3bf1b98998f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.361352 [ 35659 ] {5748f547-e16a-4937-af55-b4728535978d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.390229 [ 35675 ] {318929e3-f52a-4f0d-a617-4db97d307075} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 0, should be 1: In scope SELECT domain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domain();) 2025.06.18 11:20:45.395534 [ 35675 ] {318929e3-f52a-4f0d-a617-4db97d307075} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 0, should be 1: In scope SELECT domain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.420564 [ 35675 ] {7488e8b6-047f-4a72-bd7d-903733749434} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 0, should be 1: In scope SELECT domainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domainRFC();) 2025.06.18 11:20:45.433624 [ 35675 ] {7488e8b6-047f-4a72-bd7d-903733749434} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 0, should be 1: In scope SELECT domainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.458697 [ 35675 ] {0ed6a600-dd27-42ed-8a5e-45b4d859f78a} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domainWithoutWWW();) 2025.06.18 11:20:45.463584 [ 35675 ] {0ed6a600-dd27-42ed-8a5e-45b4d859f78a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.492441 [ 35675 ] {5230aebc-0501-46e4-87eb-20766b86bb7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domainWithoutWWWRFC();) 2025.06.18 11:20:45.497263 [ 35675 ] {5230aebc-0501-46e4-87eb-20766b86bb7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.524062 [ 35675 ] {06332cbe-ce61-4b25-949a-95f32042607a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT dotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dotProduct();) 2025.06.18 11:20:45.528681 [ 35675 ] {06332cbe-ce61-4b25-949a-95f32042607a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT dotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.557266 [ 35675 ] {8d590543-b48e-40ca-ab16-aa425b0bb4f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 0, should be 1: In scope SELECT dumpColumnStructure(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dumpColumnStructure();) 2025.06.18 11:20:45.562992 [ 35675 ] {8d590543-b48e-40ca-ab16-aa425b0bb4f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 0, should be 1: In scope SELECT dumpColumnStructure(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.594294 [ 35675 ] {8ca5f671-4a2f-4887-ac5d-7fb73842b41e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 0, should be 2: In scope SELECT dynamicElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dynamicElement();) 2025.06.18 11:20:45.599852 [ 35675 ] {8ca5f671-4a2f-4887-ac5d-7fb73842b41e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 0, should be 2: In scope SELECT dynamicElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.629268 [ 35675 ] {ee02be4b-78ea-4280-a697-ef748707a0d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 0, should be 1: In scope SELECT dynamicType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dynamicType();) 2025.06.18 11:20:45.634798 [ 35675 ] {ee02be4b-78ea-4280-a697-ef748707a0d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 0, should be 1: In scope SELECT dynamicType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.697932 [ 35659 ] {2394287b-6795-4b4c-974b-6a091ddf945e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L1Norm(NULL, NULL);) 2025.06.18 11:20:45.706069 [ 35659 ] {2394287b-6795-4b4c-974b-6a091ddf945e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.722736 [ 35675 ] {30915d63-3674-4858-91ec-0b102df99ca6} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT editDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT editDistance();) 2025.06.18 11:20:45.727382 [ 35675 ] {30915d63-3674-4858-91ec-0b102df99ca6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT editDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.740076 [ 35659 ] {3b71fd2a-f860-4551-95b8-ff389c614fa6} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L1Normalize(NULL, NULL);) 2025.06.18 11:20:45.744790 [ 35659 ] {3b71fd2a-f860-4551-95b8-ff389c614fa6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.753684 [ 35675 ] {4ab87166-5c50-4816-879c-4d4bce512b60} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT editDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT editDistanceUTF8();) 2025.06.18 11:20:45.758377 [ 35675 ] {4ab87166-5c50-4816-879c-4d4bce512b60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT editDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.785407 [ 35675 ] {917b520d-4d29-45c1-9d49-98f881adb1f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 0, should be 1: In scope SELECT empty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT empty();) 2025.06.18 11:20:45.790407 [ 35675 ] {917b520d-4d29-45c1-9d49-98f881adb1f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 0, should be 1: In scope SELECT empty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.830516 [ 35659 ] {3c378415-0b87-426f-a196-b9a4f9523a88} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L2Norm(NULL, NULL);) 2025.06.18 11:20:45.835646 [ 35659 ] {3c378415-0b87-426f-a196-b9a4f9523a88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.869883 [ 35659 ] {45ed185b-8d09-49c3-aec1-afccd944a2ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L2Normalize(NULL, NULL);) 2025.06.18 11:20:45.874898 [ 35659 ] {45ed185b-8d09-49c3-aec1-afccd944a2ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:45.962982 [ 35659 ] {e90b228b-a795-4f8f-9d3a-a3b786ba6231} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L2SquaredNorm(NULL, NULL);) 2025.06.18 11:20:45.968327 [ 35659 ] {e90b228b-a795-4f8f-9d3a-a3b786ba6231} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.129443 [ 35659 ] {da25a8e6-6c7d-4849-879f-3d9d2b9f2541} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT LinfNorm(NULL, NULL);) 2025.06.18 11:20:46.134913 [ 35659 ] {da25a8e6-6c7d-4849-879f-3d9d2b9f2541} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.169722 [ 35659 ] {4d52a4ec-808b-4f86-bd24-3f771b2fae4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT LinfNormalize(NULL, NULL);) 2025.06.18 11:20:46.174694 [ 35659 ] {4d52a4ec-808b-4f86-bd24-3f771b2fae4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.209556 [ 35659 ] {dcaa2b09-2838-4e95-ae67-1661f07b3974} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT LpDistance(NULL, NULL);) 2025.06.18 11:20:46.214956 [ 35659 ] {dcaa2b09-2838-4e95-ae67-1661f07b3974} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.335368 [ 35675 ] {e6a64b8e-923d-4856-bfa7-c1f464c62ff8} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 0, should be 1: In scope SELECT emptyArrayToSingle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT emptyArrayToSingle();) 2025.06.18 11:20:46.339005 [ 35675 ] {e6a64b8e-923d-4856-bfa7-c1f464c62ff8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 0, should be 1: In scope SELECT emptyArrayToSingle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.409956 [ 35659 ] {ae767192-9375-4b00-9d72-ff7c3ca61a62} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MACNumToString(NULL, NULL);) 2025.06.18 11:20:46.414878 [ 35659 ] {ae767192-9375-4b00-9d72-ff7c3ca61a62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.449221 [ 35659 ] {4d88775c-ac66-4ce8-a018-165677898b39} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MACStringToNum(NULL, NULL);) 2025.06.18 11:20:46.453467 [ 35659 ] {4d88775c-ac66-4ce8-a018-165677898b39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.486148 [ 35659 ] {26823912-91e1-4cdc-919f-82aaca2065ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MACStringToOUI(NULL, NULL);) 2025.06.18 11:20:46.490819 [ 35659 ] {26823912-91e1-4cdc-919f-82aaca2065ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.522148 [ 35659 ] {33fba1fd-0cd0-4292-9f11-3b64fbe90ca6} executeQuery: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL);) 2025.06.18 11:20:46.526834 [ 35659 ] {33fba1fd-0cd0-4292-9f11-3b64fbe90ca6} TCPHandler: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:46.559537 [ 35659 ] {dd88c893-5610-4890-b169-39d3fdbc678e} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MD4(NULL, NULL);) 2025.06.18 11:20:46.564310 [ 35659 ] {dd88c893-5610-4890-b169-39d3fdbc678e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.598697 [ 35659 ] {c8f55e11-ea6c-4ce9-8e62-bae0af982841} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MD5(NULL, NULL);) 2025.06.18 11:20:46.604156 [ 35659 ] {c8f55e11-ea6c-4ce9-8e62-bae0af982841} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.677055 [ 35675 ] {6669e024-4033-493c-9d1e-9f1585a3b619} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encodeURLComponent();) 2025.06.18 11:20:46.681932 [ 35675 ] {6669e024-4033-493c-9d1e-9f1585a3b619} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.705123 [ 35675 ] {0e45e5e1-4be3-4a26-af2f-c09d6ee29502} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encodeURLFormComponent();) 2025.06.18 11:20:46.709916 [ 35675 ] {0e45e5e1-4be3-4a26-af2f-c09d6ee29502} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.734019 [ 35675 ] {2800a95d-0203-41b2-9663-09ab87ff8b57} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encodeXMLComponent();) 2025.06.18 11:20:46.738927 [ 35675 ] {2800a95d-0203-41b2-9663-09ab87ff8b57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.765733 [ 35675 ] {92db207d-ef5e-4354-b617-1432cf0f0ba5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT encrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encrypt();) 2025.06.18 11:20:46.770301 [ 35675 ] {92db207d-ef5e-4354-b617-1432cf0f0ba5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT encrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.797475 [ 35675 ] {ece7d73f-3306-4202-8d70-5c25a6138e07} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 0, should be 2: In scope SELECT endsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT endsWith();) 2025.06.18 11:20:46.800884 [ 35675 ] {ece7d73f-3306-4202-8d70-5c25a6138e07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 0, should be 2: In scope SELECT endsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.813484 [ 35659 ] {b3be5f58-6133-4656-9a55-08f96deaf771} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT OCTET_LENGTH(NULL, NULL);) 2025.06.18 11:20:46.818812 [ 35659 ] {b3be5f58-6133-4656-9a55-08f96deaf771} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.826563 [ 35675 ] {8283d427-052e-4f3d-81b7-2fd7cbb4132f} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT endsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT endsWithUTF8();) 2025.06.18 11:20:46.831208 [ 35675 ] {8283d427-052e-4f3d-81b7-2fd7cbb4132f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT endsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.857863 [ 35675 ] {729698bf-7653-4593-92c4-e32db68f4222} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function entropy. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT entropy();) 2025.06.18 11:20:46.865487 [ 35675 ] {729698bf-7653-4593-92c4-e32db68f4222} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function entropy. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.889717 [ 35675 ] {72d9fdac-0fba-437d-a926-168a6dfd79bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 0, should be 2: In scope SELECT equals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT equals();) 2025.06.18 11:20:46.894394 [ 35675 ] {72d9fdac-0fba-437d-a926-168a6dfd79bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 0, should be 2: In scope SELECT equals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.918324 [ 35675 ] {b7ce75c0-985a-4672-a11c-5a40ec44a8e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 0, should be 1: In scope SELECT erf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT erf();) 2025.06.18 11:20:46.923024 [ 35675 ] {b7ce75c0-985a-4672-a11c-5a40ec44a8e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 0, should be 1: In scope SELECT erf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.947943 [ 35675 ] {07af0de5-32ad-470d-9c8f-e8bdbcacbdf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 0, should be 1: In scope SELECT erfc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT erfc();) 2025.06.18 11:20:46.952775 [ 35675 ] {07af0de5-32ad-470d-9c8f-e8bdbcacbdf5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 0, should be 1: In scope SELECT erfc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:46.978404 [ 35675 ] {b6dae270-cace-460c-b972-1a220f2013e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 0, should be 1: In scope SELECT errorCodeToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT errorCodeToName();) 2025.06.18 11:20:46.985458 [ 35675 ] {b6dae270-cace-460c-b972-1a220f2013e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 0, should be 1: In scope SELECT errorCodeToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.019591 [ 35675 ] {b4e74aa0-6e57-4b7b-a03b-08d6f814e1d0} executeQuery: Code: 36. DB::Exception: Function evalMLMethod requires at least one argument: In scope SELECT evalMLMethod(). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT evalMLMethod();) 2025.06.18 11:20:47.021743 [ 35659 ] {8c113773-af11-4b85-9c81-c768eb589c2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT REGEXP_REPLACE(NULL, NULL);) 2025.06.18 11:20:47.024218 [ 35675 ] {b4e74aa0-6e57-4b7b-a03b-08d6f814e1d0} TCPHandler: Code: 36. DB::Exception: Function evalMLMethod requires at least one argument: In scope SELECT evalMLMethod(). (BAD_ARGUMENTS) 2025.06.18 11:20:47.025111 [ 35659 ] {8c113773-af11-4b85-9c81-c768eb589c2d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.054619 [ 35675 ] {390662cf-b193-414c-a4c7-0cc2d438ffd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 0, should be 1: In scope SELECT exp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exp();) 2025.06.18 11:20:47.056760 [ 35659 ] {00427a9c-f35e-44bd-ad4d-eca082b3704e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SCHEMA(NULL, NULL);) 2025.06.18 11:20:47.059472 [ 35675 ] {390662cf-b193-414c-a4c7-0cc2d438ffd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 0, should be 1: In scope SELECT exp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.062036 [ 35659 ] {00427a9c-f35e-44bd-ad4d-eca082b3704e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.088690 [ 35675 ] {8c30def6-c8f4-43cf-823b-4e9cb038ba01} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 0, should be 1: In scope SELECT exp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exp10();) 2025.06.18 11:20:47.094235 [ 35675 ] {8c30def6-c8f4-43cf-823b-4e9cb038ba01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 0, should be 1: In scope SELECT exp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.122869 [ 35675 ] {89b234c5-d634-414d-9cc0-2a1acbf947d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 0, should be 1: In scope SELECT exp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exp2();) 2025.06.18 11:20:47.129282 [ 35675 ] {89b234c5-d634-414d-9cc0-2a1acbf947d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 0, should be 1: In scope SELECT exp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.157270 [ 35675 ] {289787f1-51ef-4455-ad07-3472a9b576f2} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialMovingAverage();) 2025.06.18 11:20:47.157270 [ 35659 ] {1bfda326-56b7-4aaa-a770-164c5ed5b7f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA1(NULL, NULL);) 2025.06.18 11:20:47.163321 [ 35675 ] {289787f1-51ef-4455-ad07-3472a9b576f2} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.164043 [ 35659 ] {1bfda326-56b7-4aaa-a770-164c5ed5b7f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.194568 [ 35675 ] {d3a2b2d5-89b4-4d17-ba15-221681adef63} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedAvg();) 2025.06.18 11:20:47.195295 [ 35659 ] {4b828c57-2825-4864-8f83-90acc9c63129} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA224(NULL, NULL);) 2025.06.18 11:20:47.200898 [ 35659 ] {4b828c57-2825-4864-8f83-90acc9c63129} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.200981 [ 35675 ] {d3a2b2d5-89b4-4d17-ba15-221681adef63} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.229676 [ 35675 ] {096e2bb2-30b2-4b12-ad7c-76e1627ad0a5} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedCount();) 2025.06.18 11:20:47.234131 [ 35659 ] {97ce0f76-a252-4404-b671-9d8827f0d7e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA256(NULL, NULL);) 2025.06.18 11:20:47.259342 [ 35675 ] {096e2bb2-30b2-4b12-ad7c-76e1627ad0a5} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.270248 [ 35659 ] {97ce0f76-a252-4404-b671-9d8827f0d7e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.288496 [ 35675 ] {a6beb6b7-a6c0-466b-8835-a5cece2a5c33} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedMax();) 2025.06.18 11:20:47.294329 [ 35675 ] {a6beb6b7-a6c0-466b-8835-a5cece2a5c33} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.307157 [ 35659 ] {d5772e27-29de-4894-874a-22325e13bb31} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA384(NULL, NULL);) 2025.06.18 11:20:47.313083 [ 35659 ] {d5772e27-29de-4894-874a-22325e13bb31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.338720 [ 35675 ] {9540c7c8-5015-483e-b98e-c6062f11ddea} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedSum();) 2025.06.18 11:20:47.345325 [ 35675 ] {9540c7c8-5015-483e-b98e-c6062f11ddea} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.365276 [ 35659 ] {8bebacb8-d297-472e-b08a-f5e34004a884} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA512(NULL, NULL);) 2025.06.18 11:20:47.371855 [ 35659 ] {8bebacb8-d297-472e-b08a-f5e34004a884} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.382182 [ 35675 ] {52590599-9437-4cae-9614-94ec2e674e7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 0, should be 2: In scope SELECT extract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extract();) 2025.06.18 11:20:47.389139 [ 35675 ] {52590599-9437-4cae-9614-94ec2e674e7a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 0, should be 2: In scope SELECT extract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.412058 [ 35659 ] {d2677ab9-ce65-4777-8a74-4828165a6820} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA512_256(NULL, NULL);) 2025.06.18 11:20:47.418559 [ 35659 ] {d2677ab9-ce65-4777-8a74-4828165a6820} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.424022 [ 35675 ] {14311aa6-a958-4a2b-817c-d79236e30f0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 0, should be 2: In scope SELECT extractAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAll();) 2025.06.18 11:20:47.430706 [ 35675 ] {14311aa6-a958-4a2b-817c-d79236e30f0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 0, should be 2: In scope SELECT extractAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.465916 [ 35675 ] {644ff2e3-c727-45f7-a604-dcb9c1ee7c93} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAllGroups();) 2025.06.18 11:20:47.472092 [ 35675 ] {644ff2e3-c727-45f7-a604-dcb9c1ee7c93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.505264 [ 35675 ] {59123661-10c5-475d-8fba-97e514e40f95} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAllGroupsHorizontal();) 2025.06.18 11:20:47.511001 [ 35675 ] {59123661-10c5-475d-8fba-97e514e40f95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.542861 [ 35675 ] {905c1c0b-86f2-461b-876b-8fb8e330aab1} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAllGroupsVertical();) 2025.06.18 11:20:47.548256 [ 35675 ] {905c1c0b-86f2-461b-876b-8fb8e330aab1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.578586 [ 35675 ] {7a96472e-7eea-482b-8c6a-83e3fbceec4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractGroups();) 2025.06.18 11:20:47.588166 [ 35675 ] {7a96472e-7eea-482b-8c6a-83e3fbceec4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.615860 [ 35675 ] {f76f18d8-7f70-42dc-998c-2cc7fed854f2} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractKeyValuePairs();) 2025.06.18 11:20:47.620922 [ 35675 ] {f76f18d8-7f70-42dc-998c-2cc7fed854f2} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.648484 [ 35675 ] {ecdfe140-624b-4c7f-beb6-45374df44801} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairsWithEscaping(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractKeyValuePairsWithEscaping();) 2025.06.18 11:20:47.652935 [ 35675 ] {ecdfe140-624b-4c7f-beb6-45374df44801} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairsWithEscaping(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.677054 [ 35675 ] {d033c326-75f9-4ad3-912c-f8a4cbd118d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 0, should be 1: In scope SELECT extractTextFromHTML(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractTextFromHTML();) 2025.06.18 11:20:47.681722 [ 35675 ] {d033c326-75f9-4ad3-912c-f8a4cbd118d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 0, should be 1: In scope SELECT extractTextFromHTML(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.698226 [ 35659 ] {a5a4bed6-9b40-433d-93e4-4df06aed4c0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SUBSTRING_INDEX(NULL, NULL);) 2025.06.18 11:20:47.704191 [ 35659 ] {a5a4bed6-9b40-433d-93e4-4df06aed4c0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.710863 [ 35675 ] {760ba1e8-7b16-42a3-9005-fc60c4c546ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 0, should be 2: In scope SELECT extractURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractURLParameter();) 2025.06.18 11:20:47.716986 [ 35675 ] {760ba1e8-7b16-42a3-9005-fc60c4c546ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 0, should be 2: In scope SELECT extractURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.741514 [ 35675 ] {34606bc9-e578-4829-9af2-a1104e828d62} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 0, should be 1: In scope SELECT extractURLParameterNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractURLParameterNames();) 2025.06.18 11:20:47.746325 [ 35675 ] {34606bc9-e578-4829-9af2-a1104e828d62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 0, should be 1: In scope SELECT extractURLParameterNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.770522 [ 35675 ] {e2677cd9-ea0e-433a-a7ca-23a9c459a510} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 0, should be 1: In scope SELECT extractURLParameters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractURLParameters();) 2025.06.18 11:20:47.775547 [ 35675 ] {e2677cd9-ea0e-433a-a7ca-23a9c459a510} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 0, should be 1: In scope SELECT extractURLParameters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.800119 [ 35675 ] {56e9e92f-54b3-45f1-a9c4-ea3ed1da85cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 0, should be 1: In scope SELECT factorial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT factorial();) 2025.06.18 11:20:47.804905 [ 35675 ] {56e9e92f-54b3-45f1-a9c4-ea3ed1da85cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 0, should be 1: In scope SELECT factorial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.863846 [ 35659 ] {7018fc3e-39f6-4684-ac99-55b1e366644b} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT TO_BASE64(NULL, NULL);) 2025.06.18 11:20:47.867061 [ 35659 ] {7018fc3e-39f6-4684-ac99-55b1e366644b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:47.934474 [ 35675 ] {904fdacb-3cdb-4b6a-941b-e182b9bfe1c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 0, should be 1 or 2: In scope SELECT file(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT file();) 2025.06.18 11:20:47.938013 [ 35675 ] {904fdacb-3cdb-4b6a-941b-e182b9bfe1c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 0, should be 1 or 2: In scope SELECT file(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.118887 [ 35675 ] {1352043c-1ea4-4c97-bbe5-0fe56d545ae1} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 0, should be 1: In scope SELECT finalizeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT finalizeAggregation();) 2025.06.18 11:20:48.123496 [ 35675 ] {1352043c-1ea4-4c97-bbe5-0fe56d545ae1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 0, should be 1: In scope SELECT finalizeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.149105 [ 35675 ] {89b9fa9d-1baf-4409-b914-b81bc4dd2508} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 0, should be 1: In scope SELECT firstLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstLine();) 2025.06.18 11:20:48.153633 [ 35675 ] {89b9fa9d-1baf-4409-b914-b81bc4dd2508} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 0, should be 1: In scope SELECT firstLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.154116 [ 35659 ] {6ad74544-d812-414d-bd43-ed3f9616ac55} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT URLHierarchy(NULL, NULL);) 2025.06.18 11:20:48.159017 [ 35659 ] {6ad74544-d812-414d-bd43-ed3f9616ac55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.183550 [ 35675 ] {78546b77-a8c3-4dee-a965-0c3e4cc7358f} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomain();) 2025.06.18 11:20:48.189402 [ 35675 ] {78546b77-a8c3-4dee-a965-0c3e4cc7358f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.201761 [ 35659 ] {dd5e0e28-bb51-413f-b8c6-2c52a0dc2a13} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT URLPathHierarchy(NULL, NULL);) 2025.06.18 11:20:48.207820 [ 35659 ] {dd5e0e28-bb51-413f-b8c6-2c52a0dc2a13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.223232 [ 35675 ] {d004d413-bb83-4ef1-99e9-f356e806403a} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomainCustom();) 2025.06.18 11:20:48.229068 [ 35675 ] {d004d413-bb83-4ef1-99e9-f356e806403a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.246329 [ 35659 ] {d86cb665-708a-4699-8802-e9d897e43993} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT UTCTimestamp(NULL, NULL);) 2025.06.18 11:20:48.252740 [ 35659 ] {d86cb665-708a-4699-8802-e9d897e43993} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.260193 [ 35675 ] {5c78a7b9-6489-4e8e-ba75-b429718ada83} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomainCustomRFC();) 2025.06.18 11:20:48.266155 [ 35675 ] {5c78a7b9-6489-4e8e-ba75-b429718ada83} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.290752 [ 35659 ] {c636e94f-3530-49a9-bad0-e3965141dcf0} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT UTC_timestamp(NULL, NULL);) 2025.06.18 11:20:48.296299 [ 35659 ] {c636e94f-3530-49a9-bad0-e3965141dcf0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.307259 [ 35675 ] {a1230eac-cc31-4c22-91eb-87ee8ab033d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomainRFC();) 2025.06.18 11:20:48.312639 [ 35675 ] {a1230eac-cc31-4c22-91eb-87ee8ab033d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.338660 [ 35675 ] {33704b06-0de1-4a97-896f-a3b3aa05026d} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT first_value();) 2025.06.18 11:20:48.342940 [ 35675 ] {33704b06-0de1-4a97-896f-a3b3aa05026d} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.368696 [ 35675 ] {37a88bcb-3014-4f85-a6e7-9b1e328bd3a8} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT first_value_respect_nulls();) 2025.06.18 11:20:48.373890 [ 35675 ] {37a88bcb-3014-4f85-a6e7-9b1e328bd3a8} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.401484 [ 35675 ] {bc0bf6f1-cad6-4159-8827-120959888905} executeQuery: Code: 42. DB::Exception: Aggregate function flameGraph requires 1 to 3 arguments : trace, [size = 1], [ptr = 0]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT flameGraph();) 2025.06.18 11:20:48.406448 [ 35675 ] {bc0bf6f1-cad6-4159-8827-120959888905} TCPHandler: Code: 42. DB::Exception: Aggregate function flameGraph requires 1 to 3 arguments : trace, [size = 1], [ptr = 0]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.431138 [ 35675 ] {8a61b5a8-3edf-466d-85a8-2a17c04c64d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT flatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT flatten();) 2025.06.18 11:20:48.436641 [ 35675 ] {8a61b5a8-3edf-466d-85a8-2a17c04c64d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT flatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.460318 [ 35675 ] {66780d80-2876-41e0-89ef-b672bf345b07} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 0, should be 1: In scope SELECT flattenTuple(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT flattenTuple();) 2025.06.18 11:20:48.465141 [ 35675 ] {66780d80-2876-41e0-89ef-b672bf345b07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 0, should be 1: In scope SELECT flattenTuple(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.491507 [ 35675 ] {6587f8d9-8458-418b-bb0f-5de043bb7894} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT floor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT floor();) 2025.06.18 11:20:48.496462 [ 35675 ] {6587f8d9-8458-418b-bb0f-5de043bb7894} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT floor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.519232 [ 35675 ] {44a8be22-fbde-49a4-bc58-2bef5e839c75} executeQuery: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 0, should be at least 2: In scope SELECT format(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT format();) 2025.06.18 11:20:48.524185 [ 35675 ] {44a8be22-fbde-49a4-bc58-2bef5e839c75} TCPHandler: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 0, should be at least 2: In scope SELECT format(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.549224 [ 35675 ] {acae8c0e-7f20-43ac-97d8-94213a019f32} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatDateTime();) 2025.06.18 11:20:48.554079 [ 35675 ] {acae8c0e-7f20-43ac-97d8-94213a019f32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.578125 [ 35675 ] {3d3c3f8d-c9c3-49cd-b19e-2fb0876776ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatDateTimeInJodaSyntax();) 2025.06.18 11:20:48.582860 [ 35675 ] {3d3c3f8d-c9c3-49cd-b19e-2fb0876776ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.608692 [ 35675 ] {eb9e548b-44ac-4c97-ac47-7f22fc3d21b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 0, should be 1: In scope SELECT formatQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQuery();) 2025.06.18 11:20:48.613705 [ 35675 ] {eb9e548b-44ac-4c97-ac47-7f22fc3d21b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 0, should be 1: In scope SELECT formatQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.639761 [ 35675 ] {e89325d8-7c85-423c-9209-49e61b19cd5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQueryOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQueryOrNull();) 2025.06.18 11:20:48.644361 [ 35675 ] {e89325d8-7c85-423c-9209-49e61b19cd5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQueryOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.674430 [ 35675 ] {bb0cb84a-a84e-4b19-a4ae-6cd89859194e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQuerySingleLine();) 2025.06.18 11:20:48.678974 [ 35675 ] {bb0cb84a-a84e-4b19-a4ae-6cd89859194e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.709552 [ 35675 ] {6cad07f6-4e76-4d03-afc9-236d2702484f} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLineOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQuerySingleLineOrNull();) 2025.06.18 11:20:48.714731 [ 35675 ] {6cad07f6-4e76-4d03-afc9-236d2702484f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLineOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.740931 [ 35675 ] {a5996e91-5506-4796-bc46-617f98e95940} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableDecimalSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableDecimalSize();) 2025.06.18 11:20:48.745967 [ 35675 ] {a5996e91-5506-4796-bc46-617f98e95940} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableDecimalSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.775063 [ 35675 ] {012cb415-1e90-455e-a7e3-0acaa98a23b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 0, should be 1: In scope SELECT formatReadableQuantity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableQuantity();) 2025.06.18 11:20:48.779030 [ 35675 ] {012cb415-1e90-455e-a7e3-0acaa98a23b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 0, should be 1: In scope SELECT formatReadableQuantity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.804278 [ 35675 ] {5b26dbc6-2e46-4773-a92d-52d387674f09} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableSize();) 2025.06.18 11:20:48.809225 [ 35675 ] {5b26dbc6-2e46-4773-a92d-52d387674f09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.837087 [ 35675 ] {4d79122e-396d-4281-ac83-a1750ecc6677} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableTimeDelta doesn't match: passed 0, should be at least 1.: In scope SELECT formatReadableTimeDelta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableTimeDelta();) 2025.06.18 11:20:48.841890 [ 35675 ] {4d79122e-396d-4281-ac83-a1750ecc6677} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableTimeDelta doesn't match: passed 0, should be at least 1.: In scope SELECT formatReadableTimeDelta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.867975 [ 35675 ] {8b47a7a7-975b-406c-a42d-b251386945ea} executeQuery: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatRow();) 2025.06.18 11:20:48.872649 [ 35675 ] {8b47a7a7-975b-406c-a42d-b251386945ea} TCPHandler: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.895254 [ 35675 ] {efdded1f-acce-4131-ac05-2b3febf660a1} executeQuery: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatRowNoNewline();) 2025.06.18 11:20:48.899910 [ 35675 ] {efdded1f-acce-4131-ac05-2b3febf660a1} TCPHandler: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.924703 [ 35675 ] {b5a7396a-aac9-4ef5-80b7-267ba509a6ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 0, should be 1: In scope SELECT fragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fragment();) 2025.06.18 11:20:48.929793 [ 35675 ] {b5a7396a-aac9-4ef5-80b7-267ba509a6ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 0, should be 1: In scope SELECT fragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.955701 [ 35675 ] {d3f4edaa-b98a-41c7-9b45-7d8f71934001} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromDaysSinceYearZero();) 2025.06.18 11:20:48.960322 [ 35675 ] {d3f4edaa-b98a-41c7-9b45-7d8f71934001} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:48.989800 [ 35675 ] {eee992ce-7835-4f6d-a117-2d74d1dd434b} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromDaysSinceYearZero32();) 2025.06.18 11:20:48.994444 [ 35675 ] {eee992ce-7835-4f6d-a117-2d74d1dd434b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.006494 [ 35659 ] {5dfce867-1324-428f-ad40-df733189820e} executeQuery: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT _CAST(NULL, NULL);) 2025.06.18 11:20:49.011864 [ 35659 ] {5dfce867-1324-428f-ad40-df733189820e} TCPHandler: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:49.018257 [ 35675 ] {680a565f-dcf2-4fc4-8d56-6f38db358f77} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromModifiedJulianDay();) 2025.06.18 11:20:49.022993 [ 35675 ] {680a565f-dcf2-4fc4-8d56-6f38db358f77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.040130 [ 35659 ] {aaaf8203-0a41-450a-9f83-0cac09f54374} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __actionName(NULL, NULL);) 2025.06.18 11:20:49.044698 [ 35659 ] {aaaf8203-0a41-450a-9f83-0cac09f54374} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:20:49.060791 [ 35675 ] {1ebd11a4-df5b-46fb-9a2e-c9d21f0a4a2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromModifiedJulianDayOrNull();) 2025.06.18 11:20:49.065692 [ 35675 ] {1ebd11a4-df5b-46fb-9a2e-c9d21f0a4a2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.094707 [ 35675 ] {ac2ab871-362c-4883-a6be-642a891361eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT fromUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUTCTimestamp();) 2025.06.18 11:20:49.099296 [ 35675 ] {ac2ab871-362c-4883-a6be-642a891361eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT fromUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.121941 [ 35675 ] {0e9827a2-20d0-45f4-8f7c-b13e79a6a08e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp();) 2025.06.18 11:20:49.127029 [ 35675 ] {0e9827a2-20d0-45f4-8f7c-b13e79a6a08e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.153437 [ 35675 ] {4e1a3b72-d39a-4940-94a3-79ac43e35184} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp64Micro();) 2025.06.18 11:20:49.158262 [ 35675 ] {4e1a3b72-d39a-4940-94a3-79ac43e35184} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.186163 [ 35675 ] {8511b5e8-fab8-4cbb-97d3-b2a2f8c8eb54} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp64Milli();) 2025.06.18 11:20:49.189446 [ 35659 ] {a6ab447c-219f-44a4-aa6c-9ea6df8e15bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __bitSwapLastTwo(NULL, NULL);) 2025.06.18 11:20:49.190938 [ 35675 ] {8511b5e8-fab8-4cbb-97d3-b2a2f8c8eb54} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.193700 [ 35659 ] {a6ab447c-219f-44a4-aa6c-9ea6df8e15bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.214716 [ 35675 ] {f063ead3-bb77-431d-bafa-ab1587ab82ec} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp64Nano();) 2025.06.18 11:20:49.219349 [ 35675 ] {f063ead3-bb77-431d-bafa-ab1587ab82ec} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.224155 [ 35659 ] {c81d1da0-f11f-4231-84f8-ccef61258f96} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __bitWrapperFunc(NULL, NULL);) 2025.06.18 11:20:49.228652 [ 35659 ] {c81d1da0-f11f-4231-84f8-ccef61258f96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.246327 [ 35675 ] {d156cbfe-460b-4d6a-b337-0d6961cff6b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestampInJodaSyntax doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestampInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestampInJodaSyntax();) 2025.06.18 11:20:49.251528 [ 35675 ] {d156cbfe-460b-4d6a-b337-0d6961cff6b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestampInJodaSyntax doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestampInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.260707 [ 35659 ] {7fa1bb20-7f51-40a6-9eb1-b74e4f466424} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __getScalar(NULL, NULL);) 2025.06.18 11:20:49.265706 [ 35659 ] {7fa1bb20-7f51-40a6-9eb1-b74e4f466424} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.277421 [ 35675 ] {17568b53-3585-402c-af05-d0391a8d5c2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT from_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT from_utc_timestamp();) 2025.06.18 11:20:49.291548 [ 35675 ] {17568b53-3585-402c-af05-d0391a8d5c2e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT from_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.296396 [ 35659 ] {64540df9-a639-4afe-ace5-c29899c9792b} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __scalarSubqueryResult(NULL, NULL);) 2025.06.18 11:20:49.301104 [ 35659 ] {64540df9-a639-4afe-ace5-c29899c9792b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.333199 [ 35659 ] {7d89b952-f1bd-46cd-960e-f216df8b9cd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT abs(NULL, NULL);) 2025.06.18 11:20:49.338744 [ 35659 ] {7d89b952-f1bd-46cd-960e-f216df8b9cd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.367524 [ 35675 ] {4105b6bc-8d7a-481d-bc4e-22ecc55baf82} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 0, should be 2: In scope SELECT fuzzBits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fuzzBits();) 2025.06.18 11:20:49.371127 [ 35675 ] {4105b6bc-8d7a-481d-bc4e-22ecc55baf82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 0, should be 2: In scope SELECT fuzzBits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.372469 [ 35659 ] {5f77523a-63e2-478d-8a4f-bec9ffdbe3af} executeQuery: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT accurateCast(NULL, NULL);) 2025.06.18 11:20:49.377571 [ 35659 ] {5f77523a-63e2-478d-8a4f-bec9ffdbe3af} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:49.406713 [ 35659 ] {552e47d9-e1c7-486e-96ca-f9533c48770c} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT accurateCastOrDefault(NULL, NULL);) 2025.06.18 11:20:49.411547 [ 35659 ] {552e47d9-e1c7-486e-96ca-f9533c48770c} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:49.447533 [ 35659 ] {44dd45bc-8c82-46a7-85ee-93a2024d9764} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT accurateCastOrNull(NULL, NULL);) 2025.06.18 11:20:49.452482 [ 35659 ] {44dd45bc-8c82-46a7-85ee-93a2024d9764} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:49.455107 [ 35675 ] {d267044a-bcad-4758-a89e-bf178e61dd91} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 0, should be 2: In scope SELECT gcd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT gcd();) 2025.06.18 11:20:49.459779 [ 35675 ] {d267044a-bcad-4758-a89e-bf178e61dd91} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 0, should be 2: In scope SELECT gcd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.483258 [ 35659 ] {852735f9-3085-4eba-b9a3-0f229c991876} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT acos(NULL, NULL);) 2025.06.18 11:20:49.488249 [ 35659 ] {852735f9-3085-4eba-b9a3-0f229c991876} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.522519 [ 35659 ] {067e175a-0483-4dcb-9082-449f8c5ba979} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT acosh(NULL, NULL);) 2025.06.18 11:20:49.528076 [ 35659 ] {067e175a-0483-4dcb-9082-449f8c5ba979} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.770581 [ 35675 ] {6c03ae97-55a7-4437-94c7-ee2222c1c868} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 0, should be 4: In scope SELECT geoDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geoDistance();) 2025.06.18 11:20:49.775326 [ 35675 ] {6c03ae97-55a7-4437-94c7-ee2222c1c868} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 0, should be 4: In scope SELECT geoDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.800764 [ 35675 ] {75592e5e-2bd3-4d9f-a347-12f811a2588b} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 0, should be 3: In scope SELECT geoToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geoToH3();) 2025.06.18 11:20:49.806639 [ 35675 ] {75592e5e-2bd3-4d9f-a347-12f811a2588b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 0, should be 3: In scope SELECT geoToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.832196 [ 35675 ] {c501ffcb-12ef-4510-ab94-57af996d26c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 0, should be 2: In scope SELECT geoToS2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geoToS2();) 2025.06.18 11:20:49.837413 [ 35675 ] {c501ffcb-12ef-4510-ab94-57af996d26c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 0, should be 2: In scope SELECT geoToS2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.871092 [ 35675 ] {3f2e0075-a937-4bc4-bdbc-1fcf48f748a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 0, should be 1: In scope SELECT geohashDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geohashDecode();) 2025.06.18 11:20:49.875585 [ 35675 ] {3f2e0075-a937-4bc4-bdbc-1fcf48f748a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 0, should be 1: In scope SELECT geohashDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.900265 [ 35675 ] {ca34235b-2345-40ab-a8c7-28352391c464} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT geohashEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geohashEncode();) 2025.06.18 11:20:49.904934 [ 35675 ] {ca34235b-2345-40ab-a8c7-28352391c464} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT geohashEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.928348 [ 35675 ] {13813d91-333a-46ea-81f7-cc16a499efde} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geohashesInBox();) 2025.06.18 11:20:49.933077 [ 35675 ] {13813d91-333a-46ea-81f7-cc16a499efde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:49.958559 [ 35675 ] {26517b68-2b9a-4b08-86c7-6b78de41025c} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getClientHTTPHeader();) 2025.06.18 11:20:49.963223 [ 35675 ] {26517b68-2b9a-4b08-86c7-6b78de41025c} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.18 11:20:49.990581 [ 35675 ] {871e9540-1a05-4b38-8004-a8c8eb9d16d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 0, should be 1: In scope SELECT getMacro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getMacro();) 2025.06.18 11:20:49.995618 [ 35675 ] {871e9540-1a05-4b38-8004-a8c8eb9d16d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 0, should be 1: In scope SELECT getMacro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.071951 [ 35675 ] {356f9369-501a-4a26-a848-1af83bcbb35b} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 0, should be 1: In scope SELECT getServerPort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getServerPort();) 2025.06.18 11:20:50.077207 [ 35675 ] {356f9369-501a-4a26-a848-1af83bcbb35b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 0, should be 1: In scope SELECT getServerPort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.103813 [ 35675 ] {0349c685-0159-4dab-bec8-94d7b26066ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 0, should be 1: In scope SELECT getSetting(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getSetting();) 2025.06.18 11:20:50.108689 [ 35675 ] {0349c685-0159-4dab-bec8-94d7b26066ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 0, should be 1: In scope SELECT getSetting(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.136863 [ 35675 ] {ffd14c53-90c0-4890-8b5e-ae7170274005} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 0, should be 1: In scope SELECT getSizeOfEnumType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getSizeOfEnumType();) 2025.06.18 11:20:50.141537 [ 35675 ] {ffd14c53-90c0-4890-8b5e-ae7170274005} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 0, should be 1: In scope SELECT getSizeOfEnumType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.165536 [ 35675 ] {ab022517-3bf4-4b75-b712-c2c5ee0c15d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 0, should be 2: In scope SELECT getSubcolumn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getSubcolumn();) 2025.06.18 11:20:50.169268 [ 35675 ] {ab022517-3bf4-4b75-b712-c2c5ee0c15d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 0, should be 2: In scope SELECT getSubcolumn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.193810 [ 35675 ] {8444d0a3-bc20-4c54-b10d-5d193b2f9549} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 0, should be 1: In scope SELECT getTypeSerializationStreams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getTypeSerializationStreams();) 2025.06.18 11:20:50.200770 [ 35675 ] {8444d0a3-bc20-4c54-b10d-5d193b2f9549} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 0, should be 1: In scope SELECT getTypeSerializationStreams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.224667 [ 35675 ] {a6b95bc8-55c4-499b-83a1-feecb002ff3d} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalIn();) 2025.06.18 11:20:50.227956 [ 35675 ] {a6b95bc8-55c4-499b-83a1-feecb002ff3d} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.251921 [ 35675 ] {82687d33-5048-46de-bd21-5d2d2562af79} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalInIgnoreSet();) 2025.06.18 11:20:50.256594 [ 35675 ] {82687d33-5048-46de-bd21-5d2d2562af79} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.281760 [ 35675 ] {db4707f9-a920-4dca-9754-ac7815f3b03e} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotIn();) 2025.06.18 11:20:50.286414 [ 35675 ] {db4707f9-a920-4dca-9754-ac7815f3b03e} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.311563 [ 35675 ] {89f222b8-ac4c-4e86-92c3-a00b697b0fc9} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotInIgnoreSet();) 2025.06.18 11:20:50.316239 [ 35675 ] {89f222b8-ac4c-4e86-92c3-a00b697b0fc9} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.339109 [ 35675 ] {1d06d9bb-0eb5-417b-abc5-2daf53c91a16} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotNullIn();) 2025.06.18 11:20:50.344304 [ 35675 ] {1d06d9bb-0eb5-417b-abc5-2daf53c91a16} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.370802 [ 35675 ] {42194a44-3e02-4988-8fd1-6a116239ce92} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotNullInIgnoreSet();) 2025.06.18 11:20:50.375326 [ 35675 ] {42194a44-3e02-4988-8fd1-6a116239ce92} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.401458 [ 35659 ] {0664de1c-da8c-4ff2-be25-fd0131092f7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT addressToLine(NULL, NULL);) 2025.06.18 11:20:50.405815 [ 35659 ] {0664de1c-da8c-4ff2-be25-fd0131092f7c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.406394 [ 35675 ] {51881710-db2f-4065-9511-88abc32d91bf} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNullIn();) 2025.06.18 11:20:50.411518 [ 35675 ] {51881710-db2f-4065-9511-88abc32d91bf} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.434248 [ 35659 ] {ad8fe97e-ae47-44be-b8a4-d0de3f0e559b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT addressToLineWithInlines(NULL, NULL);) 2025.06.18 11:20:50.434925 [ 35675 ] {b0071f14-131c-474a-9ade-42493f984626} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNullInIgnoreSet();) 2025.06.18 11:20:50.438376 [ 35675 ] {b0071f14-131c-474a-9ade-42493f984626} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.438439 [ 35659 ] {ad8fe97e-ae47-44be-b8a4-d0de3f0e559b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.462952 [ 35675 ] {ae7b6044-72ac-474b-9381-8f16f49af801} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 0, should be 1: In scope SELECT globalVariable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalVariable();) 2025.06.18 11:20:50.467511 [ 35675 ] {ae7b6044-72ac-474b-9381-8f16f49af801} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 0, should be 1: In scope SELECT globalVariable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.468132 [ 35659 ] {f0a9b506-fca2-44e2-8229-5cb0406f4efa} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT addressToSymbol(NULL, NULL);) 2025.06.18 11:20:50.472395 [ 35659 ] {f0a9b506-fca2-44e2-8229-5cb0406f4efa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.491681 [ 35675 ] {9bd8d11a-9bf8-4ae6-988e-5fc02b899f33} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 0, should be 4: In scope SELECT greatCircleAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greatCircleAngle();) 2025.06.18 11:20:50.496529 [ 35675 ] {9bd8d11a-9bf8-4ae6-988e-5fc02b899f33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 0, should be 4: In scope SELECT greatCircleAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.522865 [ 35675 ] {590a8ce8-3c1e-4b86-8490-1898c6a2159d} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 0, should be 4: In scope SELECT greatCircleDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greatCircleDistance();) 2025.06.18 11:20:50.528136 [ 35675 ] {590a8ce8-3c1e-4b86-8490-1898c6a2159d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 0, should be 4: In scope SELECT greatCircleDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.551849 [ 35675 ] {be9f87df-c23e-4db7-a66a-64ae9f5111f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 0, should be 2: In scope SELECT greater(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greater();) 2025.06.18 11:20:50.555364 [ 35675 ] {be9f87df-c23e-4db7-a66a-64ae9f5111f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 0, should be 2: In scope SELECT greater(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.579100 [ 35675 ] {96bcbc45-bc38-413f-ba38-4d1d43949c38} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 0, should be 2: In scope SELECT greaterOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greaterOrEquals();) 2025.06.18 11:20:50.583713 [ 35675 ] {96bcbc45-bc38-413f-ba38-4d1d43949c38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 0, should be 2: In scope SELECT greaterOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.609728 [ 35675 ] {0d6622e1-a4ad-4421-87e2-025b595e6d84} executeQuery: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greatest();) 2025.06.18 11:20:50.614324 [ 35675 ] {0d6622e1-a4ad-4421-87e2-025b595e6d84} TCPHandler: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.638367 [ 35675 ] {237453a0-5d5a-4ffa-9e0c-f0553d4ea1b9} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArray();) 2025.06.18 11:20:50.643146 [ 35675 ] {237453a0-5d5a-4ffa-9e0c-f0553d4ea1b9} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.669940 [ 35675 ] {e4e0333e-1c29-42fa-a89f-642c8c7a9dfc} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayInsertAt();) 2025.06.18 11:20:50.674990 [ 35675 ] {e4e0333e-1c29-42fa-a89f-642c8c7a9dfc} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.702350 [ 35675 ] {863abe04-aa76-4454-84ec-ea6ef3709b61} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayIntersect();) 2025.06.18 11:20:50.707205 [ 35675 ] {863abe04-aa76-4454-84ec-ea6ef3709b61} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.758750 [ 35675 ] {b32e8f71-8608-43a5-a8a9-48fcad906851} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayLast();) 2025.06.18 11:20:50.774991 [ 35675 ] {b32e8f71-8608-43a5-a8a9-48fcad906851} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.801849 [ 35675 ] {53770a61-da70-4c1c-a7a3-d7d8670059fb} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayMovingAvg();) 2025.06.18 11:20:50.806368 [ 35675 ] {53770a61-da70-4c1c-a7a3-d7d8670059fb} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.831466 [ 35675 ] {f90cffb1-dfde-4b49-94ea-212d86e47fb0} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayMovingSum();) 2025.06.18 11:20:50.836376 [ 35675 ] {f90cffb1-dfde-4b49-94ea-212d86e47fb0} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.861661 [ 35675 ] {51f80a6c-76fe-4159-a60b-e7099db5e7f1} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArraySample();) 2025.06.18 11:20:50.866352 [ 35675 ] {51f80a6c-76fe-4159-a60b-e7099db5e7f1} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.889508 [ 35675 ] {688e9015-13c9-454a-83e2-6b666b80a9b5} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArraySorted();) 2025.06.18 11:20:50.893123 [ 35675 ] {688e9015-13c9-454a-83e2-6b666b80a9b5} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.918397 [ 35675 ] {1c67428f-d478-4f9a-bb79-3642759c2783} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitAnd();) 2025.06.18 11:20:50.923469 [ 35675 ] {1c67428f-d478-4f9a-bb79-3642759c2783} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.949515 [ 35675 ] {b809ca3f-ffd6-4c2c-af27-edce1cabe46c} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitOr();) 2025.06.18 11:20:50.953949 [ 35675 ] {b809ca3f-ffd6-4c2c-af27-edce1cabe46c} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:50.977556 [ 35675 ] {fd2cdab5-df2a-4d00-baf6-2dca47eecaeb} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitXor();) 2025.06.18 11:20:50.981133 [ 35675 ] {fd2cdab5-df2a-4d00-baf6-2dca47eecaeb} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.004697 [ 35675 ] {ae0e90ee-b4ba-4629-91ba-7fc5d3be63ac} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmap();) 2025.06.18 11:20:51.008215 [ 35675 ] {ae0e90ee-b4ba-4629-91ba-7fc5d3be63ac} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.031636 [ 35675 ] {7cd99571-4e0d-4fbf-b289-2ff414a1aebc} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmapAnd();) 2025.06.18 11:20:51.034991 [ 35675 ] {7cd99571-4e0d-4fbf-b289-2ff414a1aebc} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.058775 [ 35675 ] {a83a6e99-eb2d-4617-bc38-3869ee5a299b} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmapOr();) 2025.06.18 11:20:51.062228 [ 35675 ] {a83a6e99-eb2d-4617-bc38-3869ee5a299b} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.088797 [ 35675 ] {eb6e1f19-6cfc-425f-831c-5786a2e2be70} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmapXor();) 2025.06.18 11:20:51.093642 [ 35675 ] {eb6e1f19-6cfc-425f-831c-5786a2e2be70} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.118235 [ 35675 ] {ff42dfde-ad79-4aa3-a842-ca0679686d89} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupConcat();) 2025.06.18 11:20:51.123065 [ 35675 ] {ff42dfde-ad79-4aa3-a842-ca0679686d89} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.146201 [ 35675 ] {2298bb7e-e6f8-4d71-b5bb-7095d5351c0f} executeQuery: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupUniqArray();) 2025.06.18 11:20:51.151210 [ 35675 ] {2298bb7e-e6f8-4d71-b5bb-7095d5351c0f} TCPHandler: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.174090 [ 35675 ] {dcd0b0c1-d438-4775-9ab3-55aed17863de} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT group_concat();) 2025.06.18 11:20:51.177503 [ 35675 ] {dcd0b0c1-d438-4775-9ab3-55aed17863de} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.200052 [ 35675 ] {fbfb63fd-685b-45f1-a602-a2cea8141638} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3CellAreaM2();) 2025.06.18 11:20:51.204804 [ 35675 ] {fbfb63fd-685b-45f1-a602-a2cea8141638} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.228134 [ 35675 ] {d66ce7b4-2e84-4030-850c-0fed82455b31} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaRads2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3CellAreaRads2();) 2025.06.18 11:20:51.231859 [ 35675 ] {d66ce7b4-2e84-4030-850c-0fed82455b31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaRads2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.238152 [ 35659 ] {a8cfe1e5-ad70-4d58-803f-d48c86e1a95e} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT anyLast_respect_nulls(NULL, NULL);) 2025.06.18 11:20:51.241496 [ 35659 ] {a8cfe1e5-ad70-4d58-803f-d48c86e1a95e} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.256368 [ 35675 ] {10dbcc1d-2c8f-43e5-9b6e-1bbdf2428f25} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 0, should be 2: In scope SELECT h3Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3Distance();) 2025.06.18 11:20:51.259918 [ 35675 ] {10dbcc1d-2c8f-43e5-9b6e-1bbdf2428f25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 0, should be 2: In scope SELECT h3Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.274657 [ 35659 ] {95b4ff79-fb09-410c-b712-e8ef32d454fc} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT any_respect_nulls(NULL, NULL);) 2025.06.18 11:20:51.278715 [ 35659 ] {95b4ff79-fb09-410c-b712-e8ef32d454fc} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.285771 [ 35675 ] {be2cf6e8-9549-44f8-9296-77f84e7d87b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 0, should be 1: In scope SELECT h3EdgeAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3EdgeAngle();) 2025.06.18 11:20:51.289406 [ 35675 ] {be2cf6e8-9549-44f8-9296-77f84e7d87b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 0, should be 1: In scope SELECT h3EdgeAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.328895 [ 35675 ] {aa4fbe1e-f53e-48f0-a49c-f738e29973e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3EdgeLengthKm();) 2025.06.18 11:20:51.335101 [ 35675 ] {aa4fbe1e-f53e-48f0-a49c-f738e29973e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.359820 [ 35675 ] {26258b3e-3078-49b7-a3ec-d33dd51f1458} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3EdgeLengthM();) 2025.06.18 11:20:51.364525 [ 35675 ] {26258b3e-3078-49b7-a3ec-d33dd51f1458} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.388814 [ 35675 ] {eb92fc63-22e6-4a3f-9e01-beac8293c486} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ExactEdgeLengthKm();) 2025.06.18 11:20:51.393010 [ 35675 ] {eb92fc63-22e6-4a3f-9e01-beac8293c486} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.393955 [ 35659 ] {55f82115-0913-4fc4-8308-4064faad3901} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT any_value_respect_nulls(NULL, NULL);) 2025.06.18 11:20:51.398879 [ 35659 ] {55f82115-0913-4fc4-8308-4064faad3901} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.419742 [ 35675 ] {1b46fad5-e35a-4513-803e-f79aa1df5e2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ExactEdgeLengthM();) 2025.06.18 11:20:51.424935 [ 35675 ] {1b46fad5-e35a-4513-803e-f79aa1df5e2c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.450989 [ 35675 ] {769c9470-6195-48ea-88b7-bf0d70af1646} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ExactEdgeLengthRads();) 2025.06.18 11:20:51.454845 [ 35675 ] {769c9470-6195-48ea-88b7-bf0d70af1646} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.487183 [ 35675 ] {ff20e159-b32e-4cfa-ae6b-1793f945f5ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 0, should be 1: In scope SELECT h3GetBaseCell(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetBaseCell();) 2025.06.18 11:20:51.493045 [ 35675 ] {ff20e159-b32e-4cfa-ae6b-1793f945f5ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 0, should be 1: In scope SELECT h3GetBaseCell(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.522734 [ 35675 ] {66948bda-c9c2-4460-9ea9-976b3f447d2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge();) 2025.06.18 11:20:51.528636 [ 35675 ] {66948bda-c9c2-4460-9ea9-976b3f447d2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.556545 [ 35675 ] {f27dab94-9815-4a27-b5a0-2f53f62a3de5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 0, should be 1: In scope SELECT h3GetFaces(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetFaces();) 2025.06.18 11:20:51.561406 [ 35675 ] {f27dab94-9815-4a27-b5a0-2f53f62a3de5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 0, should be 1: In scope SELECT h3GetFaces(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.592827 [ 35675 ] {03b8a271-49f9-4829-b7f1-99b0bb59f9b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge();) 2025.06.18 11:20:51.598476 [ 35675 ] {03b8a271-49f9-4829-b7f1-99b0bb59f9b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.622719 [ 35675 ] {24266e2e-57a2-4e0e-b46c-9ed7ffc1bea4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge();) 2025.06.18 11:20:51.626279 [ 35675 ] {24266e2e-57a2-4e0e-b46c-9ed7ffc1bea4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.646212 [ 35675 ] {33d30d22-fd73-4b9a-9993-1e07157eb691} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 0, should be 1: In scope SELECT h3GetPentagonIndexes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetPentagonIndexes();) 2025.06.18 11:20:51.649514 [ 35675 ] {33d30d22-fd73-4b9a-9993-1e07157eb691} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 0, should be 1: In scope SELECT h3GetPentagonIndexes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.768142 [ 35675 ] {6602b2ee-0529-4316-bfcd-c42e66a5fbf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 0, should be 1: In scope SELECT h3GetResolution(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetResolution();) 2025.06.18 11:20:51.771540 [ 35675 ] {6602b2ee-0529-4316-bfcd-c42e66a5fbf2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 0, should be 1: In scope SELECT h3GetResolution(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.799782 [ 35675 ] {7975beb3-3338-49d2-8ff6-7ccf44f1bc65} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 0, should be 2: In scope SELECT h3GetUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetUnidirectionalEdge();) 2025.06.18 11:20:51.803277 [ 35675 ] {7975beb3-3338-49d2-8ff6-7ccf44f1bc65} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 0, should be 2: In scope SELECT h3GetUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.826674 [ 35675 ] {7c62059b-6580-4c8b-8668-6b4a7170cf34} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary();) 2025.06.18 11:20:51.829971 [ 35675 ] {7c62059b-6580-4c8b-8668-6b4a7170cf34} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.852028 [ 35675 ] {af8c972a-60b1-42ce-9cde-d2cc0139e56a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon();) 2025.06.18 11:20:51.855277 [ 35675 ] {af8c972a-60b1-42ce-9cde-d2cc0139e56a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.875872 [ 35675 ] {fa7c17ec-dd70-4bb2-88cc-e50d03e4db4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaKm2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3HexAreaKm2();) 2025.06.18 11:20:51.879208 [ 35675 ] {fa7c17ec-dd70-4bb2-88cc-e50d03e4db4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaKm2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.903059 [ 35675 ] {a0c1df89-33a8-4c78-8150-ae6b9fe44110} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3HexAreaM2();) 2025.06.18 11:20:51.906716 [ 35675 ] {a0c1df89-33a8-4c78-8150-ae6b9fe44110} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.926454 [ 35675 ] {2478805c-793a-41c0-8b8f-5b95edb88c32} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 0, should be 2: In scope SELECT h3HexRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3HexRing();) 2025.06.18 11:20:51.929933 [ 35675 ] {2478805c-793a-41c0-8b8f-5b95edb88c32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 0, should be 2: In scope SELECT h3HexRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.950029 [ 35675 ] {fea01ac6-bdea-44d3-9933-133548c4ae52} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 0, should be 2: In scope SELECT h3IndexesAreNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IndexesAreNeighbors();) 2025.06.18 11:20:51.953090 [ 35675 ] {fea01ac6-bdea-44d3-9933-133548c4ae52} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 0, should be 2: In scope SELECT h3IndexesAreNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:51.975893 [ 35675 ] {272c0a1c-87d9-4a97-93d8-7414c521c769} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 0, should be 1: In scope SELECT h3IsPentagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IsPentagon();) 2025.06.18 11:20:51.979631 [ 35675 ] {272c0a1c-87d9-4a97-93d8-7414c521c769} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 0, should be 1: In scope SELECT h3IsPentagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.007220 [ 35675 ] {9610e19a-9faf-4e55-943b-27eb038af475} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 0, should be 1: In scope SELECT h3IsResClassIII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IsResClassIII();) 2025.06.18 11:20:52.010757 [ 35675 ] {9610e19a-9faf-4e55-943b-27eb038af475} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 0, should be 1: In scope SELECT h3IsResClassIII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.032748 [ 35675 ] {b00c460c-ed39-49c9-8022-05bc6dc42c3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 0, should be 1: In scope SELECT h3IsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IsValid();) 2025.06.18 11:20:52.036027 [ 35675 ] {b00c460c-ed39-49c9-8022-05bc6dc42c3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 0, should be 1: In scope SELECT h3IsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.057799 [ 35675 ] {0c8e3a15-c415-42d0-982f-ea0e1e137751} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 0, should be 2: In scope SELECT h3Line(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3Line();) 2025.06.18 11:20:52.061601 [ 35675 ] {0c8e3a15-c415-42d0-982f-ea0e1e137751} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 0, should be 2: In scope SELECT h3Line(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.084582 [ 35675 ] {0943aac4-1a51-4e72-892a-08eb75cab070} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 0, should be 1: In scope SELECT h3NumHexagons(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3NumHexagons();) 2025.06.18 11:20:52.088172 [ 35675 ] {0943aac4-1a51-4e72-892a-08eb75cab070} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 0, should be 1: In scope SELECT h3NumHexagons(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.108126 [ 35675 ] {e252b21e-13e5-4249-8574-db2a21e908fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 0, should be 4: In scope SELECT h3PointDistKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3PointDistKm();) 2025.06.18 11:20:52.111340 [ 35675 ] {e252b21e-13e5-4249-8574-db2a21e908fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 0, should be 4: In scope SELECT h3PointDistKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.133605 [ 35675 ] {e234e7e1-0251-4359-956b-8f92bf512452} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 0, should be 4: In scope SELECT h3PointDistM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3PointDistM();) 2025.06.18 11:20:52.136935 [ 35675 ] {e234e7e1-0251-4359-956b-8f92bf512452} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 0, should be 4: In scope SELECT h3PointDistM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.162207 [ 35675 ] {5cc7f0f9-0e3c-4860-819a-6bbc5bb630fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 0, should be 4: In scope SELECT h3PointDistRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3PointDistRads();) 2025.06.18 11:20:52.165508 [ 35675 ] {5cc7f0f9-0e3c-4860-819a-6bbc5bb630fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 0, should be 4: In scope SELECT h3PointDistRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.189000 [ 35675 ] {42e06127-9020-4bb8-aeb5-178185fe394b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 0, should be 2: In scope SELECT h3ToCenterChild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToCenterChild();) 2025.06.18 11:20:52.192100 [ 35675 ] {42e06127-9020-4bb8-aeb5-178185fe394b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 0, should be 2: In scope SELECT h3ToCenterChild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.210569 [ 35675 ] {3a2695de-4836-496f-85a9-28fe2e7e5156} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 0, should be 2: In scope SELECT h3ToChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToChildren();) 2025.06.18 11:20:52.213676 [ 35675 ] {3a2695de-4836-496f-85a9-28fe2e7e5156} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 0, should be 2: In scope SELECT h3ToChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.233306 [ 35675 ] {ebfe33bf-f299-4ab4-95bf-3c2c2bfbfae6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 0, should be 1: In scope SELECT h3ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToGeo();) 2025.06.18 11:20:52.236323 [ 35675 ] {ebfe33bf-f299-4ab4-95bf-3c2c2bfbfae6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 0, should be 1: In scope SELECT h3ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.257582 [ 35675 ] {a3dea725-a17a-4e5c-bd1d-2109278157d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 0, should be 1: In scope SELECT h3ToGeoBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToGeoBoundary();) 2025.06.18 11:20:52.261122 [ 35675 ] {a3dea725-a17a-4e5c-bd1d-2109278157d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 0, should be 1: In scope SELECT h3ToGeoBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.281379 [ 35675 ] {43372b60-1bbd-4b7a-a3bb-b4ffbae2c8fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 0, should be 2: In scope SELECT h3ToParent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToParent();) 2025.06.18 11:20:52.284517 [ 35675 ] {43372b60-1bbd-4b7a-a3bb-b4ffbae2c8fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 0, should be 2: In scope SELECT h3ToParent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.306609 [ 35675 ] {0355d120-7481-4b5f-8234-07bf1970597c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 0, should be 1: In scope SELECT h3ToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToString();) 2025.06.18 11:20:52.309820 [ 35675 ] {0355d120-7481-4b5f-8234-07bf1970597c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 0, should be 1: In scope SELECT h3ToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.331754 [ 35675 ] {546eb329-c6a6-43a0-94ba-06f6478f9f9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 0, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3UnidirectionalEdgeIsValid();) 2025.06.18 11:20:52.335092 [ 35675 ] {546eb329-c6a6-43a0-94ba-06f6478f9f9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 0, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.359364 [ 35675 ] {1dc0c2eb-467a-4201-88d7-31c174d426fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 0, should be 2: In scope SELECT h3kRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3kRing();) 2025.06.18 11:20:52.362745 [ 35675 ] {1dc0c2eb-467a-4201-88d7-31c174d426fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 0, should be 2: In scope SELECT h3kRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.428167 [ 35675 ] {d6389cb1-d4a3-4d1e-bbc8-24cadca5688c} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 0, should be 2: In scope SELECT has(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT has();) 2025.06.18 11:20:52.431933 [ 35675 ] {d6389cb1-d4a3-4d1e-bbc8-24cadca5688c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 0, should be 2: In scope SELECT has(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.456538 [ 35675 ] {5428921b-0cd7-4455-ad14-2114048eed11} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 0, should be 2: In scope SELECT hasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasAll();) 2025.06.18 11:20:52.459904 [ 35675 ] {5428921b-0cd7-4455-ad14-2114048eed11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 0, should be 2: In scope SELECT hasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.479598 [ 35675 ] {99e4fe04-7f40-4903-9202-d63e4b5ecc7d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 0, should be 2: In scope SELECT hasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasAny();) 2025.06.18 11:20:52.479614 [ 35659 ] {58ba6feb-f51e-4811-bf36-051b6ceef5ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayDistinct(NULL, NULL);) 2025.06.18 11:20:52.482982 [ 35675 ] {99e4fe04-7f40-4903-9202-d63e4b5ecc7d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 0, should be 2: In scope SELECT hasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.483584 [ 35659 ] {58ba6feb-f51e-4811-bf36-051b6ceef5ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.506636 [ 35675 ] {b917a585-8530-43e8-9f84-e5009e0afcae} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasColumnInTable();) 2025.06.18 11:20:52.510070 [ 35675 ] {b917a585-8530-43e8-9f84-e5009e0afcae} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.535154 [ 35675 ] {6be016bc-7ebe-4975-af4d-6adecd039e25} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 0, should be 2: In scope SELECT hasSubsequence(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequence();) 2025.06.18 11:20:52.540138 [ 35675 ] {6be016bc-7ebe-4975-af4d-6adecd039e25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 0, should be 2: In scope SELECT hasSubsequence(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.567199 [ 35675 ] {9c102152-70f4-4931-8957-574d346e6522} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequenceCaseInsensitive();) 2025.06.18 11:20:52.570991 [ 35675 ] {9c102152-70f4-4931-8957-574d346e6522} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.599088 [ 35675 ] {bd0e42a4-9c15-4b7f-941e-320ee4c1c0a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8();) 2025.06.18 11:20:52.602567 [ 35675 ] {bd0e42a4-9c15-4b7f-941e-320ee4c1c0a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.626370 [ 35675 ] {a3898898-3ff7-4850-972f-91fe6f978d86} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequenceUTF8();) 2025.06.18 11:20:52.629620 [ 35675 ] {a3898898-3ff7-4850-972f-91fe6f978d86} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.641903 [ 35659 ] {59c8c7f0-442d-4884-a83e-7013f686ced4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayEnumerate(NULL, NULL);) 2025.06.18 11:20:52.648100 [ 35659 ] {59c8c7f0-442d-4884-a83e-7013f686ced4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.653628 [ 35675 ] {f7624521-49e3-45a5-8a49-ae5e59f44dd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 0, should be 2: In scope SELECT hasSubstr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubstr();) 2025.06.18 11:20:52.657077 [ 35675 ] {f7624521-49e3-45a5-8a49-ae5e59f44dd7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 0, should be 2: In scope SELECT hasSubstr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.729614 [ 35675 ] {d270952a-0940-4493-b8a8-93dc61c4cbe4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 0, should be 2: In scope SELECT hasToken(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasToken();) 2025.06.18 11:20:52.733148 [ 35675 ] {d270952a-0940-4493-b8a8-93dc61c4cbe4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 0, should be 2: In scope SELECT hasToken(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.758392 [ 35675 ] {b20ee41f-5aab-435e-be95-42c6847ae81b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasTokenCaseInsensitive();) 2025.06.18 11:20:52.761939 [ 35675 ] {b20ee41f-5aab-435e-be95-42c6847ae81b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.787059 [ 35675 ] {e053f3a2-0410-41a2-a32b-d50c6cde320a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasTokenCaseInsensitiveOrNull();) 2025.06.18 11:20:52.790739 [ 35675 ] {e053f3a2-0410-41a2-a32b-d50c6cde320a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.815195 [ 35675 ] {f90d1f09-b3ed-4140-98c1-f3e512237aa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasTokenOrNull();) 2025.06.18 11:20:52.820194 [ 35675 ] {f90d1f09-b3ed-4140-98c1-f3e512237aa9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.850301 [ 35675 ] {761aeca0-d97f-4768-87ad-36ff3f9706cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 0, should be 1: In scope SELECT hex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hex();) 2025.06.18 11:20:52.853998 [ 35675 ] {761aeca0-d97f-4768-87ad-36ff3f9706cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 0, should be 1: In scope SELECT hex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.878784 [ 35675 ] {193a36fa-5c02-4dd4-922b-af7ccf53f5ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hilbertDecode();) 2025.06.18 11:20:52.882505 [ 35675 ] {193a36fa-5c02-4dd4-922b-af7ccf53f5ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:52.912812 [ 35675 ] {d6388c8e-f3e1-4dbe-9949-5d792bbd156b} executeQuery: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hilbertEncode();) 2025.06.18 11:20:52.917231 [ 35675 ] {d6388c8e-f3e1-4dbe-9949-5d792bbd156b} TCPHandler: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:52.946533 [ 35675 ] {a87a2a86-2920-4e5f-a677-d5f93a3668b9} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT histogram();) 2025.06.18 11:20:52.952902 [ 35675 ] {a87a2a86-2920-4e5f-a677-d5f93a3668b9} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.035630 [ 35675 ] {24eb5c50-8e6f-4889-8578-534f705d27fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 0, should be 3 or 4: In scope SELECT hop(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hop();) 2025.06.18 11:20:53.040860 [ 35675 ] {24eb5c50-8e6f-4889-8578-534f705d27fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 0, should be 3 or 4: In scope SELECT hop(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.069179 [ 35675 ] {0098cffe-a5df-4e8a-b346-a99ff05f642d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 0, should be 3 or 4: In scope SELECT hopEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hopEnd();) 2025.06.18 11:20:53.073426 [ 35675 ] {0098cffe-a5df-4e8a-b346-a99ff05f642d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 0, should be 3 or 4: In scope SELECT hopEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.103423 [ 35675 ] {dcf5157b-2270-4196-88a1-6cf6bacc9ee1} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 0, should be 3 or 4: In scope SELECT hopStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hopStart();) 2025.06.18 11:20:53.107937 [ 35675 ] {dcf5157b-2270-4196-88a1-6cf6bacc9ee1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 0, should be 3 or 4: In scope SELECT hopStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.235244 [ 35675 ] {fa9f3d50-0f40-4427-99a2-49e31627fd86} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 0, should be 2: In scope SELECT hypot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hypot();) 2025.06.18 11:20:53.238909 [ 35675 ] {fa9f3d50-0f40-4427-99a2-49e31627fd86} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 0, should be 2: In scope SELECT hypot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.264846 [ 35675 ] {804b29d5-3315-4709-b819-d1245c04c714} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 0, should be 1: In scope SELECT identity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT identity();) 2025.06.18 11:20:53.268526 [ 35675 ] {804b29d5-3315-4709-b819-d1245c04c714} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 0, should be 1: In scope SELECT identity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.294199 [ 35675 ] {83760a95-86fd-43b0-87b2-8fe7475e48c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 0, should be 1: In scope SELECT idnaDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT idnaDecode();) 2025.06.18 11:20:53.297682 [ 35675 ] {83760a95-86fd-43b0-87b2-8fe7475e48c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 0, should be 1: In scope SELECT idnaDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.322178 [ 35675 ] {9afda49b-cdf5-4129-b9d2-7262173a3a12} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 0, should be 1: In scope SELECT idnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT idnaEncode();) 2025.06.18 11:20:53.326477 [ 35675 ] {9afda49b-cdf5-4129-b9d2-7262173a3a12} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 0, should be 1: In scope SELECT idnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.337495 [ 35659 ] {074e4e74-6cb6-4043-b595-a1b521e98ae4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayFlatten(NULL, NULL);) 2025.06.18 11:20:53.341543 [ 35659 ] {074e4e74-6cb6-4043-b595-a1b521e98ae4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.350025 [ 35675 ] {f62f8a11-7dc6-4a5c-95f4-dbbbab289863} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT if();) 2025.06.18 11:20:53.353535 [ 35675 ] {f62f8a11-7dc6-4a5c-95f4-dbbbab289863} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.375224 [ 35659 ] {ddf3d194-5a57-4d65-8340-4c96b4df7630} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayFold(NULL, NULL);) 2025.06.18 11:20:53.375210 [ 35675 ] {6e33c59c-9c8e-4a4a-9404-4e3453ac6fc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 0, should be 2: In scope SELECT ifNotFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ifNotFinite();) 2025.06.18 11:20:53.379905 [ 35659 ] {ddf3d194-5a57-4d65-8340-4c96b4df7630} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:53.380049 [ 35675 ] {6e33c59c-9c8e-4a4a-9404-4e3453ac6fc4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 0, should be 2: In scope SELECT ifNotFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.405999 [ 35675 ] {bf44dd67-0619-405b-8d49-5ec79f726a3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 0, should be 2: In scope SELECT ifNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ifNull();) 2025.06.18 11:20:53.410074 [ 35675 ] {bf44dd67-0619-405b-8d49-5ec79f726a3a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 0, should be 2: In scope SELECT ifNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.474014 [ 35047 ] {28ff8655-015a-418a-9c41-62c7230fe60b} executeQuery: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37438) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge() ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdc6535 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:53.476966 [ 35047 ] {28ff8655-015a-418a-9c41-62c7230fe60b} TCPHandler: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdc6535 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:53.481089 [ 35675 ] {f446f7a3-6395-43d0-afb6-1d0f1253508f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 0, should be 2: In scope SELECT ilike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ilike();) 2025.06.18 11:20:53.485120 [ 35675 ] {f446f7a3-6395-43d0-afb6-1d0f1253508f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 0, should be 2: In scope SELECT ilike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.514677 [ 35675 ] {869d036f-9b8f-4dbd-aad8-60ec3a287cde} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT in();) 2025.06.18 11:20:53.518589 [ 35675 ] {869d036f-9b8f-4dbd-aad8-60ec3a287cde} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.526895 [ 35659 ] {740da235-2fea-4ddd-8ef2-64ce0e8e69e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayJoin(NULL, NULL);) 2025.06.18 11:20:53.531559 [ 35659 ] {740da235-2fea-4ddd-8ef2-64ce0e8e69e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.540433 [ 35675 ] {b229b8b3-4e67-4ff9-915c-89bd686e1b39} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT inIgnoreSet();) 2025.06.18 11:20:53.544224 [ 35675 ] {b229b8b3-4e67-4ff9-915c-89bd686e1b39} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.616978 [ 35675 ] {db0fe75d-d582-4601-a079-017a41f19524} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 0, should be 2: In scope SELECT indexOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT indexOf();) 2025.06.18 11:20:53.620776 [ 35675 ] {db0fe75d-d582-4601-a079-017a41f19524} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 0, should be 2: In scope SELECT indexOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.647346 [ 35675 ] {fd753271-ca4f-43a7-a829-1914267c4dd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 0, should be 1: In scope SELECT initcap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT initcap();) 2025.06.18 11:20:53.650820 [ 35675 ] {fd753271-ca4f-43a7-a829-1914267c4dd0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 0, should be 1: In scope SELECT initcap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.675204 [ 35675 ] {2eee8435-78f7-4c43-8f37-972b77b9cb47} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 0, should be 1: In scope SELECT initcapUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT initcapUTF8();) 2025.06.18 11:20:53.688640 [ 35675 ] {2eee8435-78f7-4c43-8f37-972b77b9cb47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 0, should be 1: In scope SELECT initcapUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.803294 [ 35675 ] {3b1fc7ce-971f-4f25-afd6-9647da2dd134} executeQuery: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 0, should be at least 2.: In scope SELECT initializeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT initializeAggregation();) 2025.06.18 11:20:53.807217 [ 35675 ] {3b1fc7ce-971f-4f25-afd6-9647da2dd134} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 0, should be at least 2.: In scope SELECT initializeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.833679 [ 35675 ] {639f56d8-d93c-492a-a68b-dafbea2a9886} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT instr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT instr();) 2025.06.18 11:20:53.837308 [ 35675 ] {639f56d8-d93c-492a-a68b-dafbea2a9886} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT instr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.862723 [ 35675 ] {3d3c6744-a9df-495f-94d1-d7c42ffc2a64} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 0, should be 2: In scope SELECT intDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intDiv();) 2025.06.18 11:20:53.867394 [ 35675 ] {3d3c6744-a9df-495f-94d1-d7c42ffc2a64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 0, should be 2: In scope SELECT intDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.894046 [ 35675 ] {4dd89a0b-6734-4531-a050-e39104747780} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 0, should be 2: In scope SELECT intDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intDivOrZero();) 2025.06.18 11:20:53.898626 [ 35675 ] {4dd89a0b-6734-4531-a050-e39104747780} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 0, should be 2: In scope SELECT intDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.924125 [ 35675 ] {ad01cec2-d598-41eb-a958-c6a26440288c} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 0, should be 1: In scope SELECT intExp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intExp10();) 2025.06.18 11:20:53.927632 [ 35675 ] {ad01cec2-d598-41eb-a958-c6a26440288c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 0, should be 1: In scope SELECT intExp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.952982 [ 35675 ] {9574c190-d255-4823-afd6-f5d3953843ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 0, should be 1: In scope SELECT intExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intExp2();) 2025.06.18 11:20:53.956672 [ 35675 ] {9574c190-d255-4823-afd6-f5d3953843ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 0, should be 1: In scope SELECT intExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:53.981508 [ 35675 ] {81e18217-7e7b-449f-8951-6f19ab6300c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 0, should be 1: In scope SELECT intHash32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intHash32();) 2025.06.18 11:20:53.985375 [ 35675 ] {81e18217-7e7b-449f-8951-6f19ab6300c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 0, should be 1: In scope SELECT intHash32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.005335 [ 35675 ] {5f26bb8f-dd66-455d-93c7-30c0e5be7f4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 0, should be 1: In scope SELECT intHash64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intHash64();) 2025.06.18 11:20:54.008655 [ 35675 ] {5f26bb8f-dd66-455d-93c7-30c0e5be7f4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 0, should be 1: In scope SELECT intHash64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.032474 [ 35675 ] {17a9a0ea-d9c7-4a94-b1ca-5b321936b7b9} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intervalLengthSum();) 2025.06.18 11:20:54.036090 [ 35675 ] {17a9a0ea-d9c7-4a94-b1ca-5b321936b7b9} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.058285 [ 35675 ] {36527112-98aa-4911-bd36-e0ef5d9fba06} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isConstant();) 2025.06.18 11:20:54.062080 [ 35675 ] {36527112-98aa-4911-bd36-e0ef5d9fba06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.062261 [ 35659 ] {bfb7b593-e5d8-418f-a415-543a181a8abf} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayPopBack(NULL, NULL);) 2025.06.18 11:20:54.065890 [ 35659 ] {bfb7b593-e5d8-418f-a415-543a181a8abf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.069968 [ 612 ] {eca7aad6-cd30-4e5a-871b-f9e2af76fed4} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_xq06ovdu.test_constraints (fd434ce7-bbd2-4618-a0dc-092aec40c485) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37558) (comment: 00953_constraints_operations.sh) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:54.074545 [ 612 ] {eca7aad6-cd30-4e5a-871b-f9e2af76fed4} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_xq06ovdu.test_constraints (fd434ce7-bbd2-4618-a0dc-092aec40c485) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:54.075893 [ 35047 ] {f5c12809-5d19-423f-8a0b-9f333f1d46e8} executeQuery: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_zozh0wc1`, or there are no tables in database matches `test_zozh0wc1`, which fit tables expression: ^t. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37438) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge('^t') ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000002fdcf2d7 4. ./build_docker/./src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x000000002fdc9e5a 5. ./contrib/llvm-project/libcxx/include/__tree:153: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x000000002fdc9b84 6. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fdc6a92 7. ./build_docker/./src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdc89b9 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:54.078524 [ 35047 ] {f5c12809-5d19-423f-8a0b-9f333f1d46e8} TCPHandler: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_zozh0wc1`, or there are no tables in database matches `test_zozh0wc1`, which fit tables expression: ^t. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000002fdcf2d7 4. ./build_docker/./src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x000000002fdc9e5a 5. ./contrib/llvm-project/libcxx/include/__tree:153: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x000000002fdc9b84 6. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fdc6a92 7. ./build_docker/./src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdc89b9 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:54.085706 [ 35675 ] {535c4367-2f15-43d6-bea3-c0144042bf55} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 0, should be 1 or 2.: In scope SELECT isDecimalOverflow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isDecimalOverflow();) 2025.06.18 11:20:54.089344 [ 35675 ] {535c4367-2f15-43d6-bea3-c0144042bf55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 0, should be 1 or 2.: In scope SELECT isDecimalOverflow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.092581 [ 35659 ] {843fc3a2-c781-419a-b25c-e7ae635758ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayPopFront(NULL, NULL);) 2025.06.18 11:20:54.095891 [ 35659 ] {843fc3a2-c781-419a-b25c-e7ae635758ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.110555 [ 35675 ] {acd4dd22-51f5-4030-909e-13c92362b973} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 0, should be 1: In scope SELECT isDynamicElementInSharedData(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isDynamicElementInSharedData();) 2025.06.18 11:20:54.113559 [ 35675 ] {acd4dd22-51f5-4030-909e-13c92362b973} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 0, should be 1: In scope SELECT isDynamicElementInSharedData(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.136388 [ 35675 ] {6da29b95-be4e-400d-b1f9-1744cf290643} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 0, should be 1: In scope SELECT isFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isFinite();) 2025.06.18 11:20:54.139744 [ 35675 ] {6da29b95-be4e-400d-b1f9-1744cf290643} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 0, should be 1: In scope SELECT isFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.165873 [ 35675 ] {e52ca0fa-748c-4d41-ab9d-edc8fe0ea73b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 0, should be 2: In scope SELECT isIPAddressInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isIPAddressInRange();) 2025.06.18 11:20:54.169638 [ 35675 ] {e52ca0fa-748c-4d41-ab9d-edc8fe0ea73b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 0, should be 2: In scope SELECT isIPAddressInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.195617 [ 35675 ] {fa26148e-19f8-4e5f-aca0-4a795925dbc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 0, should be 1: In scope SELECT isIPv4String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isIPv4String();) 2025.06.18 11:20:54.199218 [ 35675 ] {fa26148e-19f8-4e5f-aca0-4a795925dbc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 0, should be 1: In scope SELECT isIPv4String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.226276 [ 35675 ] {0a5933ea-b297-4c29-9efd-aa7e43062ab5} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 0, should be 1: In scope SELECT isIPv6String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isIPv6String();) 2025.06.18 11:20:54.229937 [ 35675 ] {0a5933ea-b297-4c29-9efd-aa7e43062ab5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 0, should be 1: In scope SELECT isIPv6String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.254706 [ 35675 ] {8b129272-45b1-4fe8-b2d4-ee33b8bd1d65} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 0, should be 1: In scope SELECT isInfinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isInfinite();) 2025.06.18 11:20:54.258134 [ 35675 ] {8b129272-45b1-4fe8-b2d4-ee33b8bd1d65} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 0, should be 1: In scope SELECT isInfinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.282896 [ 35675 ] {43fc1d08-e3ba-4da5-9597-5f019d59ac00} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 0, should be 1: In scope SELECT isNaN(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNaN();) 2025.06.18 11:20:54.286383 [ 35675 ] {43fc1d08-e3ba-4da5-9597-5f019d59ac00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 0, should be 1: In scope SELECT isNaN(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.308392 [ 35675 ] {f719c3c6-6ffd-46d7-8269-3073255cf036} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNotDistinctFrom();) 2025.06.18 11:20:54.311744 [ 35675 ] {f719c3c6-6ffd-46d7-8269-3073255cf036} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.335851 [ 35675 ] {cc57f2aa-e811-4768-ac44-b1e25aa51084} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 0, should be 1: In scope SELECT isNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNotNull();) 2025.06.18 11:20:54.339524 [ 35675 ] {cc57f2aa-e811-4768-ac44-b1e25aa51084} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 0, should be 1: In scope SELECT isNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.345732 [ 35659 ] {6cfc2506-38bf-438e-9a51-76bbe8afb656} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayReduce(NULL, NULL);) 2025.06.18 11:20:54.348880 [ 35659 ] {6cfc2506-38bf-438e-9a51-76bbe8afb656} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:54.365307 [ 35675 ] {c911d083-daf7-4b12-898a-61234636124b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 0, should be 1: In scope SELECT isNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNull();) 2025.06.18 11:20:54.368980 [ 35675 ] {c911d083-daf7-4b12-898a-61234636124b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 0, should be 1: In scope SELECT isNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.392405 [ 35675 ] {c7addb4b-14ca-450e-979a-b7a5304c7ae4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 0, should be 1: In scope SELECT isNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNullable();) 2025.06.18 11:20:54.396104 [ 35675 ] {c7addb4b-14ca-450e-979a-b7a5304c7ae4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 0, should be 1: In scope SELECT isNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.421005 [ 35675 ] {5e4b7369-0c0e-48ac-afbc-4e9bb9717da2} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isValidJSON();) 2025.06.18 11:20:54.427064 [ 35675 ] {5e4b7369-0c0e-48ac-afbc-4e9bb9717da2} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.452113 [ 35675 ] {d8a5ce20-b76a-4b92-9278-7dd94056197c} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT isValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isValidUTF8();) 2025.06.18 11:20:54.455513 [ 35675 ] {d8a5ce20-b76a-4b92-9278-7dd94056197c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT isValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.479280 [ 35659 ] {73847686-acda-4233-89f4-8d4796f043a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayReverse(NULL, NULL);) 2025.06.18 11:20:54.479281 [ 35675 ] {7c4d1fd4-48e9-4a4c-8e2b-664f3a43639b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 0, should be 1: In scope SELECT isZeroOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isZeroOrNull();) 2025.06.18 11:20:54.482789 [ 35659 ] {73847686-acda-4233-89f4-8d4796f043a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.482789 [ 35675 ] {7c4d1fd4-48e9-4a4c-8e2b-664f3a43639b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 0, should be 1: In scope SELECT isZeroOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.507764 [ 35675 ] {0837faf5-767a-4ba1-8193-3638595370e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jaroSimilarity();) 2025.06.18 11:20:54.511117 [ 35675 ] {0837faf5-767a-4ba1-8193-3638595370e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.535978 [ 35675 ] {9d6fe688-c986-4617-94f6-67a4cdb3df0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroWinklerSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jaroWinklerSimilarity();) 2025.06.18 11:20:54.539497 [ 35675 ] {9d6fe688-c986-4617-94f6-67a4cdb3df0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroWinklerSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.670713 [ 35675 ] {8e09c9ad-f1d3-45cc-86d4-02f600c9df7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT joinGet();) 2025.06.18 11:20:54.674185 [ 35675 ] {8e09c9ad-f1d3-45cc-86d4-02f600c9df7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.697145 [ 35675 ] {ca81db66-b64e-47a4-9610-e6e01d17630b} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT joinGetOrNull();) 2025.06.18 11:20:54.700706 [ 35675 ] {ca81db66-b64e-47a4-9610-e6e01d17630b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.723513 [ 35675 ] {eb9c8f1b-f41d-4911-8689-1e0dd02d5ed9} executeQuery: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT jsonMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jsonMergePatch();) 2025.06.18 11:20:54.726784 [ 35675 ] {eb9c8f1b-f41d-4911-8689-1e0dd02d5ed9} TCPHandler: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT jsonMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:54.749268 [ 35675 ] {2e9d07e8-502e-4b51-b4af-677f194c6e96} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 0, should be 2: In scope SELECT jumpConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jumpConsistentHash();) 2025.06.18 11:20:54.752556 [ 35675 ] {2e9d07e8-502e-4b51-b4af-677f194c6e96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 0, should be 2: In scope SELECT jumpConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.819855 [ 35675 ] {5ef6ed59-f424-45fb-a566-2e98596c2649} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kolmogorovSmirnovTest();) 2025.06.18 11:20:54.823094 [ 35675 ] {5ef6ed59-f424-45fb-a566-2e98596c2649} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.845406 [ 35675 ] {76131dd0-428f-46d3-83ee-a0c164f453f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT kostikConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kostikConsistentHash();) 2025.06.18 11:20:54.848694 [ 35675 ] {76131dd0-428f-46d3-83ee-a0c164f453f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT kostikConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.870397 [ 35675 ] {9f6a36f0-6119-48a1-8c36-1164992af706} executeQuery: Code: 35. DB::Exception: Function kql_array_sort_asc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_asc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kql_array_sort_asc();) 2025.06.18 11:20:54.873681 [ 35675 ] {9f6a36f0-6119-48a1-8c36-1164992af706} TCPHandler: Code: 35. DB::Exception: Function kql_array_sort_asc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_asc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:54.902480 [ 35675 ] {44ff9589-6d6b-462f-905e-6da3793721fc} executeQuery: Code: 35. DB::Exception: Function kql_array_sort_desc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_desc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kql_array_sort_desc();) 2025.06.18 11:20:54.907207 [ 35675 ] {44ff9589-6d6b-462f-905e-6da3793721fc} TCPHandler: Code: 35. DB::Exception: Function kql_array_sort_desc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_desc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:54.934692 [ 35675 ] {cb78bdc8-2dee-4d2d-b1ea-611a671e2d82} executeQuery: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kurtPop();) 2025.06.18 11:20:54.938562 [ 35675 ] {cb78bdc8-2dee-4d2d-b1ea-611a671e2d82} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.966297 [ 35675 ] {875d7e70-ce04-4dab-80ce-d8c58766545a} executeQuery: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kurtSamp();) 2025.06.18 11:20:54.970479 [ 35675 ] {875d7e70-ce04-4dab-80ce-d8c58766545a} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:54.998204 [ 35675 ] {3a550eb6-dba1-4d9b-a067-af70351a0f2c} executeQuery: Code: 35. DB::Exception: Function lagInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lagInFrame();) 2025.06.18 11:20:55.002115 [ 35675 ] {3a550eb6-dba1-4d9b-a067-af70351a0f2c} TCPHandler: Code: 35. DB::Exception: Function lagInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:55.027229 [ 35675 ] {c5937896-195c-4fd9-953c-db909dd63849} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT largestTriangleThreeBuckets();) 2025.06.18 11:20:55.030762 [ 35675 ] {c5937896-195c-4fd9-953c-db909dd63849} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.054542 [ 35675 ] {643bca90-affb-473c-b967-0df39ef1c6f9} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT last_value();) 2025.06.18 11:20:55.058806 [ 35675 ] {643bca90-affb-473c-b967-0df39ef1c6f9} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.087425 [ 35675 ] {e03d311a-e82c-494d-bb4a-c8ae8e2330b7} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT last_value_respect_nulls();) 2025.06.18 11:20:55.092269 [ 35675 ] {e03d311a-e82c-494d-bb4a-c8ae8e2330b7} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.121281 [ 35675 ] {cc2bbeb4-1752-4cd1-8ec7-d35c64dd46de} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lcase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lcase();) 2025.06.18 11:20:55.124859 [ 35675 ] {cc2bbeb4-1752-4cd1-8ec7-d35c64dd46de} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lcase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.150294 [ 35675 ] {02d8da36-7909-4b15-8fd4-1b23215ef233} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 0, should be 2: In scope SELECT lcm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lcm();) 2025.06.18 11:20:55.154221 [ 35675 ] {02d8da36-7909-4b15-8fd4-1b23215ef233} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 0, should be 2: In scope SELECT lcm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.178076 [ 35675 ] {dd4b290d-f956-4397-8a7a-0c1a3547bd50} executeQuery: Code: 35. DB::Exception: Function leadInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leadInFrame();) 2025.06.18 11:20:55.181442 [ 35675 ] {dd4b290d-f956-4397-8a7a-0c1a3547bd50} TCPHandler: Code: 35. DB::Exception: Function leadInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:55.205587 [ 35675 ] {5e454c3c-1f80-4cab-98d7-f84b6a852947} executeQuery: Code: 42. DB::Exception: Function least cannot be called without arguments: In scope SELECT least(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT least();) 2025.06.18 11:20:55.209112 [ 35675 ] {5e454c3c-1f80-4cab-98d7-f84b6a852947} TCPHandler: Code: 42. DB::Exception: Function least cannot be called without arguments: In scope SELECT least(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.233626 [ 35675 ] {3099cd97-27d4-4803-996b-fe731acd7bcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 0, should be 2: In scope SELECT left(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT left();) 2025.06.18 11:20:55.237455 [ 35675 ] {3099cd97-27d4-4803-996b-fe731acd7bcf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 0, should be 2: In scope SELECT left(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.261275 [ 35675 ] {89c43d08-234c-4bea-8903-3bcac967abe3} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leftPad();) 2025.06.18 11:20:55.264787 [ 35675 ] {89c43d08-234c-4bea-8903-3bcac967abe3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.289143 [ 35675 ] {3e8334ef-9fa2-4514-878c-c20dc25119fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leftPadUTF8();) 2025.06.18 11:20:55.292388 [ 35675 ] {3e8334ef-9fa2-4514-878c-c20dc25119fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.315402 [ 35675 ] {58a68ed0-b017-4a95-8f7e-8f64b2a97672} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 0, should be 2: In scope SELECT leftUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leftUTF8();) 2025.06.18 11:20:55.318876 [ 35675 ] {58a68ed0-b017-4a95-8f7e-8f64b2a97672} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 0, should be 2: In scope SELECT leftUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.324509 [ 35659 ] {bcfcb9dd-2277-4635-b817-50d1a2460bf5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayWithConstant(NULL, NULL);) 2025.06.18 11:20:55.327743 [ 35659 ] {bcfcb9dd-2277-4635-b817-50d1a2460bf5} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:55.340784 [ 35675 ] {b877bcd2-410b-4653-986a-b5110d1b7994} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lemmatize();) 2025.06.18 11:20:55.343872 [ 35675 ] {b877bcd2-410b-4653-986a-b5110d1b7994} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:20:55.365416 [ 35675 ] {9fcfb0cf-3a21-4ad0-8429-f78920ae86b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT length(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT length();) 2025.06.18 11:20:55.368711 [ 35675 ] {9fcfb0cf-3a21-4ad0-8429-f78920ae86b3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT length(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.391902 [ 35675 ] {3b7288ce-0625-44e2-805d-c18083f62ed0} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT lengthUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lengthUTF8();) 2025.06.18 11:20:55.395236 [ 35675 ] {3b7288ce-0625-44e2-805d-c18083f62ed0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT lengthUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.418627 [ 35675 ] {212c5bb9-0e43-4fdb-8730-e94fe452e772} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 0, should be 2: In scope SELECT less(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT less();) 2025.06.18 11:20:55.421989 [ 35675 ] {212c5bb9-0e43-4fdb-8730-e94fe452e772} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 0, should be 2: In scope SELECT less(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.447927 [ 35675 ] {09805b7e-d8b0-46b7-9db7-0a215dfb0d78} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 0, should be 2: In scope SELECT lessOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lessOrEquals();) 2025.06.18 11:20:55.451495 [ 35675 ] {09805b7e-d8b0-46b7-9db7-0a215dfb0d78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 0, should be 2: In scope SELECT lessOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.472477 [ 35675 ] {325ca557-add1-4f79-a567-e49f15c0da6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT levenshteinDistance();) 2025.06.18 11:20:55.475014 [ 35659 ] {7e32524e-f2a8-489d-8981-25a10d613916} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT array_concat_agg(NULL, NULL);) 2025.06.18 11:20:55.475960 [ 35675 ] {325ca557-add1-4f79-a567-e49f15c0da6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.478289 [ 35659 ] {7e32524e-f2a8-489d-8981-25a10d613916} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:55.500229 [ 35675 ] {28e7e13b-b34d-4b98-91c0-816fbd6b08a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT levenshteinDistanceUTF8();) 2025.06.18 11:20:55.503425 [ 35675 ] {28e7e13b-b34d-4b98-91c0-816fbd6b08a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.511432 [ 35659 ] {c2331f9b-b24d-47ff-b2eb-c2105aca0325} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ascii(NULL, NULL);) 2025.06.18 11:20:55.515031 [ 35659 ] {c2331f9b-b24d-47ff-b2eb-c2105aca0325} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.525527 [ 35675 ] {796f8b24-13fc-440a-8278-134366cb842e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 0, should be 1: In scope SELECT lgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lgamma();) 2025.06.18 11:20:55.528769 [ 35675 ] {796f8b24-13fc-440a-8278-134366cb842e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 0, should be 1: In scope SELECT lgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.544475 [ 35659 ] {9bb54664-5cd2-4bf6-974b-855d506af9a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT asin(NULL, NULL);) 2025.06.18 11:20:55.548069 [ 35659 ] {9bb54664-5cd2-4bf6-974b-855d506af9a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.551205 [ 35675 ] {eb1a5180-20a4-493e-a4a5-1a193ba501fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 0, should be 2: In scope SELECT like(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT like();) 2025.06.18 11:20:55.554513 [ 35675 ] {eb1a5180-20a4-493e-a4a5-1a193ba501fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 0, should be 2: In scope SELECT like(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.576661 [ 35659 ] {c412a084-2611-42c9-819b-904b763747f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT asinh(NULL, NULL);) 2025.06.18 11:20:55.578270 [ 35675 ] {3730fa22-94e9-4ca2-bcf5-a8adba007ded} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT ln(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ln();) 2025.06.18 11:20:55.580246 [ 35659 ] {c412a084-2611-42c9-819b-904b763747f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.581682 [ 35675 ] {3730fa22-94e9-4ca2-bcf5-a8adba007ded} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT ln(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.582880 [ 35664 ] {d8ee95b0-331d-4a59-9529-346705cb67d2} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON _shard_num = b.shard_num. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37372) (comment: 01018_Distributed__shard_num.sql) (in query: SELECT _shard_num, key, b.host_name, b.host_address IN ('::1', '127.0.0.1'), b.port FROM dist_1 a JOIN system.clusters b ON _shard_num = b.shard_num WHERE b.cluster = 'test_cluster_two_shards_localhost';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034ce8672 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdaf1b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:55.585212 [ 35664 ] {d8ee95b0-331d-4a59-9529-346705cb67d2} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON _shard_num = b.shard_num. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034ce8672 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdaf1b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:55.606498 [ 35675 ] {4b429d5c-ab50-4d93-b0c4-9191c4ee10e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT locate();) 2025.06.18 11:20:55.606934 [ 35659 ] {1d3b8108-f435-4d16-b48e-1c13f1342b9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT assumeNotNull(NULL, NULL);) 2025.06.18 11:20:55.610283 [ 35675 ] {4b429d5c-ab50-4d93-b0c4-9191c4ee10e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.610479 [ 35659 ] {1d3b8108-f435-4d16-b48e-1c13f1342b9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.634313 [ 35675 ] {e0653a26-e8b3-440c-96f6-6bd970323e97} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT log(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log();) 2025.06.18 11:20:55.637737 [ 35675 ] {e0653a26-e8b3-440c-96f6-6bd970323e97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT log(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.640638 [ 35659 ] {ddb5ed9c-f0de-48d1-9f09-fad3170d3187} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT atan(NULL, NULL);) 2025.06.18 11:20:55.644069 [ 35659 ] {ddb5ed9c-f0de-48d1-9f09-fad3170d3187} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.661409 [ 35675 ] {fe581c41-b273-4bd0-93d3-85b46b3eead7} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 0, should be 1: In scope SELECT log10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log10();) 2025.06.18 11:20:55.664718 [ 35675 ] {fe581c41-b273-4bd0-93d3-85b46b3eead7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 0, should be 1: In scope SELECT log10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.697282 [ 35675 ] {f23b06f8-71b8-4851-8d97-673972f5eb3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 0, should be 1: In scope SELECT log1p(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log1p();) 2025.06.18 11:20:55.700480 [ 35675 ] {f23b06f8-71b8-4851-8d97-673972f5eb3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 0, should be 1: In scope SELECT log1p(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.721917 [ 35675 ] {2a9801da-6497-4f8e-ad6b-74d3b29e8d31} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 0, should be 1: In scope SELECT log2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log2();) 2025.06.18 11:20:55.724714 [ 35659 ] {226fc7fb-9799-4aae-8e59-c3b7fe990cce} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT atanh(NULL, NULL);) 2025.06.18 11:20:55.725256 [ 35675 ] {2a9801da-6497-4f8e-ad6b-74d3b29e8d31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 0, should be 1: In scope SELECT log2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.728236 [ 35659 ] {226fc7fb-9799-4aae-8e59-c3b7fe990cce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.748022 [ 35675 ] {8f785276-2cdc-4061-87d7-cc0fcc88047e} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 0, should be 1: In scope SELECT logTrace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT logTrace();) 2025.06.18 11:20:55.751456 [ 35675 ] {8f785276-2cdc-4061-87d7-cc0fcc88047e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 0, should be 1: In scope SELECT logTrace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.775027 [ 35675 ] {bb74a71c-d9a8-48ca-bfa0-0af1ec00abcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lowCardinalityIndices();) 2025.06.18 11:20:55.778263 [ 35675 ] {bb74a71c-d9a8-48ca-bfa0-0af1ec00abcc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.793240 [ 35664 ] {0ef8176c-7bc2-4924-8d14-8c0e784b34f2} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON a._shard_num = b.shard_num. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37372) (comment: 01018_Distributed__shard_num.sql) (in query: -- the same with JOIN, just in case SELECT a._shard_num, a.key, b.host_name, b.host_address IN ('::1', '127.0.0.1'), b.port FROM dist_1 a JOIN system.clusters b ON a._shard_num = b.shard_num WHERE b.cluster = 'test_cluster_two_shards_localhost';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034ce8672 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdaf1b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:55.796214 [ 35664 ] {0ef8176c-7bc2-4924-8d14-8c0e784b34f2} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON a._shard_num = b.shard_num. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034ce8672 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdaf1b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:55.802645 [ 35675 ] {f4081b88-a025-4927-ab5d-4366ca97f29e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lowCardinalityKeys();) 2025.06.18 11:20:55.806558 [ 35675 ] {f4081b88-a025-4927-ab5d-4366ca97f29e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.829655 [ 35675 ] {3c43fb58-b6e7-43d3-9cfc-94cdc3278bef} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lower(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lower();) 2025.06.18 11:20:55.833081 [ 35675 ] {3c43fb58-b6e7-43d3-9cfc-94cdc3278bef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lower(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.856331 [ 35675 ] {9a56ba92-255c-4616-8252-bc6796c0925a} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 0, should be 1: In scope SELECT lowerUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lowerUTF8();) 2025.06.18 11:20:55.859942 [ 35675 ] {9a56ba92-255c-4616-8252-bc6796c0925a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 0, should be 1: In scope SELECT lowerUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.883684 [ 35675 ] {3f1c4f55-0dcc-4c34-ab43-ac8fbf3c9ff8} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT lpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lpad();) 2025.06.18 11:20:55.887104 [ 35675 ] {3f1c4f55-0dcc-4c34-ab43-ac8fbf3c9ff8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT lpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.914464 [ 35675 ] {ab92aa81-8a43-4556-9a46-e9b3e71b5913} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lttb();) 2025.06.18 11:20:55.917883 [ 35675 ] {ab92aa81-8a43-4556-9a46-e9b3e71b5913} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.936294 [ 35659 ] {a6d37ce3-1509-4870-a411-8b14a29cc25f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base58Decode(NULL, NULL);) 2025.06.18 11:20:55.939721 [ 35659 ] {a6d37ce3-1509-4870-a411-8b14a29cc25f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.943302 [ 35675 ] {542a94aa-313d-4cb4-bd2b-c1c643880818} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDate();) 2025.06.18 11:20:55.947283 [ 35675 ] {542a94aa-313d-4cb4-bd2b-c1c643880818} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.967845 [ 35659 ] {75491403-0d6f-48c7-88cd-3b5581af68e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base58Encode(NULL, NULL);) 2025.06.18 11:20:55.971219 [ 35659 ] {75491403-0d6f-48c7-88cd-3b5581af68e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:55.971858 [ 35675 ] {d6c038c7-5c72-43b8-994a-8f59cd42a618} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDate32();) 2025.06.18 11:20:55.975780 [ 35675 ] {d6c038c7-5c72-43b8-994a-8f59cd42a618} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.001639 [ 35675 ] {bec79333-17fe-4d15-9b1c-08f61e9b8399} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT makeDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDateTime();) 2025.06.18 11:20:56.001853 [ 35659 ] {aba8823f-081b-44ec-8852-372468ad2aa0} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64Decode(NULL, NULL);) 2025.06.18 11:20:56.005338 [ 35675 ] {bec79333-17fe-4d15-9b1c-08f61e9b8399} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT makeDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.030521 [ 35675 ] {9d30816b-0800-4473-b45c-3dff7bc94659} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 0 arguments: In scope SELECT makeDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDateTime64();) 2025.06.18 11:20:56.031742 [ 35659 ] {aba8823f-081b-44ec-8852-372468ad2aa0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.034097 [ 35675 ] {9d30816b-0800-4473-b45c-3dff7bc94659} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 0 arguments: In scope SELECT makeDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.058545 [ 35675 ] {5ff0e14c-c70b-44a2-8cef-7e085e6ecb45} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mannWhitneyUTest();) 2025.06.18 11:20:56.061596 [ 35659 ] {cfba3a0a-16b5-4389-ac2d-9dba7f3d1e31} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64Encode(NULL, NULL);) 2025.06.18 11:20:56.062189 [ 35675 ] {5ff0e14c-c70b-44a2-8cef-7e085e6ecb45} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.064916 [ 35659 ] {cfba3a0a-16b5-4389-ac2d-9dba7f3d1e31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.096900 [ 35659 ] {76a81bb2-1492-46d8-8d5c-6d6212719fdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64URLDecode(NULL, NULL);) 2025.06.18 11:20:56.100406 [ 35659 ] {76a81bb2-1492-46d8-8d5c-6d6212719fdd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.129527 [ 35659 ] {03213d96-22de-4bff-ae8b-4583cbb26606} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64URLEncode(NULL, NULL);) 2025.06.18 11:20:56.133046 [ 35659 ] {03213d96-22de-4bff-ae8b-4583cbb26606} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.135413 [ 35675 ] {454812df-0c4e-4d95-9e83-40ca8dd14bbb} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapAdd();) 2025.06.18 11:20:56.138879 [ 35675 ] {454812df-0c4e-4d95-9e83-40ca8dd14bbb} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.162247 [ 35675 ] {3718cfbd-2998-47b5-8d33-9489e31e1477} executeQuery: Code: 42. DB::Exception: Function mapAll requires at least one argument, passed 0: In scope SELECT mapAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapAll();) 2025.06.18 11:20:56.162837 [ 35659 ] {f93e869f-ab5c-4b52-82d4-e14583085e5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT basename(NULL, NULL);) 2025.06.18 11:20:56.165863 [ 35675 ] {3718cfbd-2998-47b5-8d33-9489e31e1477} TCPHandler: Code: 42. DB::Exception: Function mapAll requires at least one argument, passed 0: In scope SELECT mapAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.166524 [ 35659 ] {f93e869f-ab5c-4b52-82d4-e14583085e5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.190331 [ 35675 ] {a51e3fb8-b43e-4919-b6fb-cb79faff326f} executeQuery: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapApply();) 2025.06.18 11:20:56.194201 [ 35675 ] {a51e3fb8-b43e-4919-b6fb-cb79faff326f} TCPHandler: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.197717 [ 35659 ] {306cb846-9837-427d-ab4e-6d449ffb8f09} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bin(NULL, NULL);) 2025.06.18 11:20:56.201705 [ 35659 ] {306cb846-9837-427d-ab4e-6d449ffb8f09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.218802 [ 35675 ] {5c79b853-e6be-4aa9-851f-fbbac472e95b} executeQuery: Code: 42. DB::Exception: Function mapConcat requires at least one argument, passed 0: In scope SELECT mapConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapConcat();) 2025.06.18 11:20:56.222434 [ 35675 ] {5c79b853-e6be-4aa9-851f-fbbac472e95b} TCPHandler: Code: 42. DB::Exception: Function mapConcat requires at least one argument, passed 0: In scope SELECT mapConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.246776 [ 35675 ] {9735b2a6-d6ef-40d7-9eeb-cb3d50acddbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 0, should be 2: In scope SELECT mapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapContains();) 2025.06.18 11:20:56.250482 [ 35675 ] {9735b2a6-d6ef-40d7-9eeb-cb3d50acddbb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 0, should be 2: In scope SELECT mapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.275269 [ 35675 ] {c5822495-eafd-4885-b1aa-60a591a10acb} executeQuery: Code: 42. DB::Exception: Function mapContainsKeyLike requires at least one argument, passed 0: In scope SELECT mapContainsKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapContainsKeyLike();) 2025.06.18 11:20:56.278874 [ 35675 ] {c5822495-eafd-4885-b1aa-60a591a10acb} TCPHandler: Code: 42. DB::Exception: Function mapContainsKeyLike requires at least one argument, passed 0: In scope SELECT mapContainsKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.290465 [ 35659 ] {057873e3-651d-403f-9725-fbc450812687} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitCount(NULL, NULL);) 2025.06.18 11:20:56.294009 [ 35659 ] {057873e3-651d-403f-9725-fbc450812687} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.303749 [ 35675 ] {5eeb4e2e-43ad-4e00-9d5b-10ae4807782c} executeQuery: Code: 42. DB::Exception: Function mapExists requires at least one argument, passed 0: In scope SELECT mapExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapExists();) 2025.06.18 11:20:56.307757 [ 35675 ] {5eeb4e2e-43ad-4e00-9d5b-10ae4807782c} TCPHandler: Code: 42. DB::Exception: Function mapExists requires at least one argument, passed 0: In scope SELECT mapExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.331310 [ 35675 ] {590f86c5-cf7e-42b1-ac96-6d64ab423441} executeQuery: Code: 42. DB::Exception: Function mapExtractKeyLike requires at least one argument, passed 0: In scope SELECT mapExtractKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapExtractKeyLike();) 2025.06.18 11:20:56.334854 [ 35675 ] {590f86c5-cf7e-42b1-ac96-6d64ab423441} TCPHandler: Code: 42. DB::Exception: Function mapExtractKeyLike requires at least one argument, passed 0: In scope SELECT mapExtractKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.360674 [ 35675 ] {e11156af-faaa-4835-8ec3-605541b06284} executeQuery: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapFilter();) 2025.06.18 11:20:56.364844 [ 35675 ] {e11156af-faaa-4835-8ec3-605541b06284} TCPHandler: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.380024 [ 35659 ] {39d03246-f0c7-4681-920f-ee704fc500ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitNot(NULL, NULL);) 2025.06.18 11:20:56.383540 [ 35659 ] {39d03246-f0c7-4681-920f-ee704fc500ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.392056 [ 35675 ] {335f13f0-fe3b-496c-98eb-ab0c70f0a475} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT mapFromArrays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapFromArrays();) 2025.06.18 11:20:56.395632 [ 35675 ] {335f13f0-fe3b-496c-98eb-ab0c70f0a475} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT mapFromArrays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.420516 [ 35675 ] {db661d28-66ad-4374-b115-c92b8dc73ac2} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT mapFromString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapFromString();) 2025.06.18 11:20:56.424294 [ 35675 ] {db661d28-66ad-4374-b115-c92b8dc73ac2} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT mapFromString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.449543 [ 35675 ] {2114f673-234d-47a2-8cf2-795cff3f29c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 0, should be 1: In scope SELECT mapKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapKeys();) 2025.06.18 11:20:56.453215 [ 35675 ] {2114f673-234d-47a2-8cf2-795cff3f29c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 0, should be 1: In scope SELECT mapKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.466663 [ 35659 ] {47bb0411-24fd-4f4f-a57a-9c6126909cdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitPositionsToArray(NULL, NULL);) 2025.06.18 11:20:56.470141 [ 35659 ] {47bb0411-24fd-4f4f-a57a-9c6126909cdf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.478319 [ 35675 ] {e1b286f0-48cc-4388-ba0b-a023125f133c} executeQuery: Code: 42. DB::Exception: Function mapPartialReverseSort requires at least one argument, passed 0: In scope SELECT mapPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapPartialReverseSort();) 2025.06.18 11:20:56.481950 [ 35675 ] {e1b286f0-48cc-4388-ba0b-a023125f133c} TCPHandler: Code: 42. DB::Exception: Function mapPartialReverseSort requires at least one argument, passed 0: In scope SELECT mapPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.512918 [ 35675 ] {a00558a1-81a6-443a-9426-f14efb9ea877} executeQuery: Code: 42. DB::Exception: Function mapPartialSort requires at least one argument, passed 0: In scope SELECT mapPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapPartialSort();) 2025.06.18 11:20:56.518184 [ 35675 ] {a00558a1-81a6-443a-9426-f14efb9ea877} TCPHandler: Code: 42. DB::Exception: Function mapPartialSort requires at least one argument, passed 0: In scope SELECT mapPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.547336 [ 35675 ] {10efcfb8-b291-4f74-ba9b-aafe89cb0fbb} executeQuery: Code: 42. DB::Exception: Function mapPopulateSeries accepts at least one map or two arrays arguments, and optional max key argument: In scope SELECT mapPopulateSeries(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapPopulateSeries();) 2025.06.18 11:20:56.550841 [ 35675 ] {10efcfb8-b291-4f74-ba9b-aafe89cb0fbb} TCPHandler: Code: 42. DB::Exception: Function mapPopulateSeries accepts at least one map or two arrays arguments, and optional max key argument: In scope SELECT mapPopulateSeries(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.574641 [ 35675 ] {aa03f1e0-ba35-4b71-ba50-57ff897edd58} executeQuery: Code: 42. DB::Exception: Function mapReverseSort requires at least one argument, passed 0: In scope SELECT mapReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapReverseSort();) 2025.06.18 11:20:56.578159 [ 35675 ] {aa03f1e0-ba35-4b71-ba50-57ff897edd58} TCPHandler: Code: 42. DB::Exception: Function mapReverseSort requires at least one argument, passed 0: In scope SELECT mapReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.602246 [ 35675 ] {b2177ca1-806f-4dbd-99be-cc9d900d5364} executeQuery: Code: 42. DB::Exception: Function mapSort requires at least one argument, passed 0: In scope SELECT mapSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapSort();) 2025.06.18 11:20:56.605757 [ 35675 ] {b2177ca1-806f-4dbd-99be-cc9d900d5364} TCPHandler: Code: 42. DB::Exception: Function mapSort requires at least one argument, passed 0: In scope SELECT mapSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.631206 [ 35675 ] {0bbf76db-282c-459b-bcd0-7cf24b7badb2} executeQuery: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapSubtract();) 2025.06.18 11:20:56.634960 [ 35675 ] {0bbf76db-282c-459b-bcd0-7cf24b7badb2} TCPHandler: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.659707 [ 35675 ] {2a0bf5d8-2167-4aeb-9d7a-84067850cb10} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapUpdate();) 2025.06.18 11:20:56.663283 [ 35675 ] {2a0bf5d8-2167-4aeb-9d7a-84067850cb10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.688112 [ 35675 ] {b57bc483-76ee-4435-ba3c-2b577d97e60b} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 0, should be 1: In scope SELECT mapValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapValues();) 2025.06.18 11:20:56.691679 [ 35675 ] {b57bc483-76ee-4435-ba3c-2b577d97e60b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 0, should be 1: In scope SELECT mapValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.715972 [ 35675 ] {2d7bc3b9-0d13-4490-8a52-038dc613f3e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT match(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT match();) 2025.06.18 11:20:56.719379 [ 35675 ] {2d7bc3b9-0d13-4490-8a52-038dc613f3e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT match(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.743703 [ 35675 ] {f69bae0a-64db-4695-a2db-e35e153aa4e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 0, should be 1: In scope SELECT materialize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT materialize();) 2025.06.18 11:20:56.747097 [ 35675 ] {f69bae0a-64db-4695-a2db-e35e153aa4e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 0, should be 1: In scope SELECT materialize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.775907 [ 35675 ] {09b4517b-7a76-4956-8271-39b7ca760d7c} executeQuery: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT max();) 2025.06.18 11:20:56.779364 [ 35675 ] {09b4517b-7a76-4956-8271-39b7ca760d7c} TCPHandler: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.803927 [ 35675 ] {2be5b3e2-546a-4b93-b182-f3d4fb9b00ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 0, should be 2: In scope SELECT max2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT max2();) 2025.06.18 11:20:56.807322 [ 35675 ] {2be5b3e2-546a-4b93-b182-f3d4fb9b00ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 0, should be 2: In scope SELECT max2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.832778 [ 35675 ] {716f600e-cf98-4b42-a2e5-804b6510b22f} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT maxIntersections();) 2025.06.18 11:20:56.836811 [ 35675 ] {716f600e-cf98-4b42-a2e5-804b6510b22f} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.864391 [ 35675 ] {f7f58b2a-2bef-4134-abe8-a3ebdb6062d5} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT maxIntersectionsPosition();) 2025.06.18 11:20:56.868344 [ 35675 ] {f7f58b2a-2bef-4134-abe8-a3ebdb6062d5} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.892347 [ 35675 ] {c7320305-f795-4ccd-88a7-de0ad7b5121f} executeQuery: Code: 42. DB::Exception: Aggregate function maxMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT maxMappedArrays();) 2025.06.18 11:20:56.895781 [ 35675 ] {c7320305-f795-4ccd-88a7-de0ad7b5121f} TCPHandler: Code: 42. DB::Exception: Aggregate function maxMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.920719 [ 35675 ] {2e5988ef-b3a1-4fe9-896d-defd4f38df5e} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT meanZTest();) 2025.06.18 11:20:56.924017 [ 35675 ] {2e5988ef-b3a1-4fe9-896d-defd4f38df5e} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:56.947589 [ 35675 ] {e931ccdd-6e2f-4d97-a343-54e42c4a75a0} executeQuery: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT median();) 2025.06.18 11:20:56.951375 [ 35675 ] {e931ccdd-6e2f-4d97-a343-54e42c4a75a0} TCPHandler: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:56.978263 [ 35675 ] {d120928f-8250-4a65-ab20-14fd1356b974} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianBFloat16();) 2025.06.18 11:20:56.981907 [ 35675 ] {d120928f-8250-4a65-ab20-14fd1356b974} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.005846 [ 35675 ] {d2c7f9ff-0061-4b25-9f0b-735f3235d82a} executeQuery: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianBFloat16Weighted();) 2025.06.18 11:20:57.009267 [ 35675 ] {d2c7f9ff-0061-4b25-9f0b-735f3235d82a} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:57.033411 [ 35675 ] {7db7341b-4a0b-4416-a4e7-d2cd79831238} executeQuery: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianDD();) 2025.06.18 11:20:57.036936 [ 35675 ] {7db7341b-4a0b-4416-a4e7-d2cd79831238} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:57.061435 [ 35675 ] {ffbaa643-d7cb-48c6-8c19-dbab155f0c73} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianDeterministic();) 2025.06.18 11:20:57.065651 [ 35675 ] {ffbaa643-d7cb-48c6-8c19-dbab155f0c73} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.089117 [ 35675 ] {4a35649d-1e1e-4d01-a598-0eb80b0554bf} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExact();) 2025.06.18 11:20:57.092631 [ 35675 ] {4a35649d-1e1e-4d01-a598-0eb80b0554bf} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.115229 [ 35675 ] {87556bcc-9857-4f4a-940d-47559091e0b2} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExactHigh();) 2025.06.18 11:20:57.118721 [ 35675 ] {87556bcc-9857-4f4a-940d-47559091e0b2} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:57.139754 [ 35675 ] {b1586f0c-5397-4234-8bbf-f0f12b958c82} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExactLow();) 2025.06.18 11:20:57.142789 [ 35675 ] {b1586f0c-5397-4234-8bbf-f0f12b958c82} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.161557 [ 35675 ] {20f007b0-fed0-450c-b97a-fd5e7c9cb71a} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExactWeighted();) 2025.06.18 11:20:57.164589 [ 35675 ] {20f007b0-fed0-450c-b97a-fd5e7c9cb71a} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.185433 [ 35675 ] {04f41df9-d1d7-4d24-b681-c17c83046d4b} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianGK();) 2025.06.18 11:20:57.188361 [ 35675 ] {04f41df9-d1d7-4d24-b681-c17c83046d4b} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.197122 [ 35659 ] {2cd41d56-f51d-4653-b606-211d6a7217e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapBuild(NULL, NULL);) 2025.06.18 11:20:57.199995 [ 35659 ] {2cd41d56-f51d-4653-b606-211d6a7217e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.207513 [ 35675 ] {b7d11b3a-41c6-493b-8b5a-51a6c35b76cb} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianInterpolatedWeighted();) 2025.06.18 11:20:57.210173 [ 35675 ] {b7d11b3a-41c6-493b-8b5a-51a6c35b76cb} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.225326 [ 35659 ] {8d81c33c-371b-4f7e-9abf-828b555bcc34} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapCardinality(NULL, NULL);) 2025.06.18 11:20:57.227537 [ 35675 ] {39820f32-cd57-4c2c-aa5b-a7f72a51a914} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTDigest();) 2025.06.18 11:20:57.227998 [ 35659 ] {8d81c33c-371b-4f7e-9abf-828b555bcc34} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.230075 [ 35675 ] {39820f32-cd57-4c2c-aa5b-a7f72a51a914} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.247575 [ 35675 ] {90457079-31cd-41f9-8222-7af98a62fea7} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTDigestWeighted();) 2025.06.18 11:20:57.250463 [ 35675 ] {90457079-31cd-41f9-8222-7af98a62fea7} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.267894 [ 35675 ] {7d6b754f-73da-4495-9e93-3fd224d2d1ca} executeQuery: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTiming();) 2025.06.18 11:20:57.270504 [ 35675 ] {7d6b754f-73da-4495-9e93-3fd224d2d1ca} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:57.289110 [ 35675 ] {2758808d-f5b1-45db-b6d2-ef30e5b7262d} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTimingWeighted();) 2025.06.18 11:20:57.291759 [ 35675 ] {2758808d-f5b1-45db-b6d2-ef30e5b7262d} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.319411 [ 35636 ] {3586c8eb-1513-458f-8695-3ef03f5830ef} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3EdgeLengthM is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3EdgeLengthM(100). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37680) (comment: 01074_h3_range_check.sql) (in query: SELECT h3EdgeLengthM(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3EdgeLengthM::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001233cbde 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:57.321593 [ 35636 ] {3586c8eb-1513-458f-8695-3ef03f5830ef} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3EdgeLengthM is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3EdgeLengthM(100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3EdgeLengthM::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001233cbde 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:57.349843 [ 35675 ] {74be0b0e-5124-4a38-b6ec-2aacf48332f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT mid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mid();) 2025.06.18 11:20:57.352928 [ 35675 ] {74be0b0e-5124-4a38-b6ec-2aacf48332f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT mid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.371730 [ 35675 ] {a87f46c2-cb96-4260-9c29-ad19113167c5} executeQuery: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT min();) 2025.06.18 11:20:57.374709 [ 35675 ] {a87f46c2-cb96-4260-9c29-ad19113167c5} TCPHandler: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.394553 [ 35675 ] {ae57825b-43f6-4616-a87c-f5d30872749c} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 0, should be 2: In scope SELECT min2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT min2();) 2025.06.18 11:20:57.397419 [ 35675 ] {ae57825b-43f6-4616-a87c-f5d30872749c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 0, should be 2: In scope SELECT min2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.416864 [ 35675 ] {8a08bbfd-3184-4be7-8d7d-598efcd46745} executeQuery: Code: 42. DB::Exception: Aggregate function minMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minMappedArrays();) 2025.06.18 11:20:57.420118 [ 35675 ] {8a08bbfd-3184-4be7-8d7d-598efcd46745} TCPHandler: Code: 42. DB::Exception: Aggregate function minMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.422812 [ 36000 ] {57988593-8fc4-4bdf-a988-781d291960c2} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_xq06ovdu.test_constraints (fd434ce7-bbd2-4618-a0dc-092aec40c485) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37726) (comment: 00953_constraints_operations.sh) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:57.427447 [ 36000 ] {57988593-8fc4-4bdf-a988-781d291960c2} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_xq06ovdu.test_constraints (fd434ce7-bbd2-4618-a0dc-092aec40c485) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x00000000327743a7 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b79cdbe 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:57.428849 [ 35659 ] {45095bd9-8512-4f51-9cbc-ab1d9fcc6890} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapMax(NULL, NULL);) 2025.06.18 11:20:57.432386 [ 35659 ] {45095bd9-8512-4f51-9cbc-ab1d9fcc6890} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.441219 [ 35675 ] {334414e1-cd10-45ab-969d-afcde0880833} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minSampleSizeContinous();) 2025.06.18 11:20:57.444294 [ 35675 ] {334414e1-cd10-45ab-969d-afcde0880833} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.458482 [ 35659 ] {13c6757a-c8cf-4627-b616-ccd8fd1c4224} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapMin(NULL, NULL);) 2025.06.18 11:20:57.461829 [ 35659 ] {13c6757a-c8cf-4627-b616-ccd8fd1c4224} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.465525 [ 35675 ] {45e91e63-8af3-42cd-85ea-c32b31e0d90c} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinuous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minSampleSizeContinuous();) 2025.06.18 11:20:57.468472 [ 35675 ] {45e91e63-8af3-42cd-85ea-c32b31e0d90c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinuous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.488369 [ 35675 ] {a41c7a79-8d38-4ee8-a5ef-ea76f5a7f4ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 0, should be 4: In scope SELECT minSampleSizeConversion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minSampleSizeConversion();) 2025.06.18 11:20:57.492483 [ 35675 ] {a41c7a79-8d38-4ee8-a5ef-ea76f5a7f4ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 0, should be 4: In scope SELECT minSampleSizeConversion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.516321 [ 35675 ] {a7949448-27e1-4a84-801a-672aa22fc04d} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 0, should be 2: In scope SELECT minus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minus();) 2025.06.18 11:20:57.519932 [ 35675 ] {a7949448-27e1-4a84-801a-672aa22fc04d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 0, should be 2: In scope SELECT minus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.538149 [ 35675 ] {a2a3aca5-1053-499b-b6fd-c13ab34044e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT mismatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mismatches();) 2025.06.18 11:20:57.541662 [ 35675 ] {a2a3aca5-1053-499b-b6fd-c13ab34044e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT mismatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.565163 [ 35675 ] {5487d3dc-cd48-47c5-8253-4f37dc1b805c} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT mod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mod();) 2025.06.18 11:20:57.568712 [ 35675 ] {5487d3dc-cd48-47c5-8253-4f37dc1b805c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT mod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.593445 [ 35675 ] {aebfe3f0-3340-4d0a-82db-37c5b9672f84} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT modulo();) 2025.06.18 11:20:57.596638 [ 35659 ] {b8c27b17-8e2f-40ac-ae1a-bde18a5e5bbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapSubsetInRange(NULL, NULL);) 2025.06.18 11:20:57.597126 [ 35675 ] {aebfe3f0-3340-4d0a-82db-37c5b9672f84} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.600692 [ 35659 ] {b8c27b17-8e2f-40ac-ae1a-bde18a5e5bbc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.622708 [ 35675 ] {0d3b2bd7-1ae7-4b0e-a18a-f75c809f1407} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 0, should be 2: In scope SELECT moduloLegacy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT moduloLegacy();) 2025.06.18 11:20:57.626528 [ 35675 ] {0d3b2bd7-1ae7-4b0e-a18a-f75c809f1407} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 0, should be 2: In scope SELECT moduloLegacy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.628877 [ 35659 ] {6012802f-c500-4ca9-b12e-f0f7b7485ac0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapSubsetLimit(NULL, NULL);) 2025.06.18 11:20:57.632301 [ 35659 ] {6012802f-c500-4ca9-b12e-f0f7b7485ac0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.653412 [ 35675 ] {31e373b5-da62-483a-99fb-f80d451c5eb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 0, should be 2: In scope SELECT moduloOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT moduloOrZero();) 2025.06.18 11:20:57.657842 [ 35675 ] {31e373b5-da62-483a-99fb-f80d451c5eb1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 0, should be 2: In scope SELECT moduloOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.659521 [ 35659 ] {c4e49971-38b9-44ee-8788-56e70ac50149} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapToArray(NULL, NULL);) 2025.06.18 11:20:57.662847 [ 35659 ] {c4e49971-38b9-44ee-8788-56e70ac50149} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.682706 [ 35675 ] {a90f7017-92f5-44e6-86c0-526755534c39} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 0, should be 1: In scope SELECT monthName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT monthName();) 2025.06.18 11:20:57.686645 [ 35675 ] {a90f7017-92f5-44e6-86c0-526755534c39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 0, should be 1: In scope SELECT monthName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.689681 [ 35659 ] {420cf02d-27a8-4010-a56a-b2b381ad8009} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapTransform(NULL, NULL);) 2025.06.18 11:20:57.692962 [ 35659 ] {420cf02d-27a8-4010-a56a-b2b381ad8009} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.711721 [ 35675 ] {991b7795-7130-42c9-aaae-8894eeb26687} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 0, should be 2: In scope SELECT mortonDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mortonDecode();) 2025.06.18 11:20:57.714836 [ 35675 ] {991b7795-7130-42c9-aaae-8894eeb26687} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 0, should be 2: In scope SELECT mortonDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.736987 [ 35675 ] {fdac1d0f-2092-4c3e-b53e-6737cb2f1920} executeQuery: Code: 35. DB::Exception: At least one UInt argument is required for function mortonEncode: In scope SELECT mortonEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mortonEncode();) 2025.06.18 11:20:57.740268 [ 35675 ] {fdac1d0f-2092-4c3e-b53e-6737cb2f1920} TCPHandler: Code: 35. DB::Exception: At least one UInt argument is required for function mortonEncode: In scope SELECT mortonEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:57.763769 [ 35675 ] {f437e368-5f37-4200-ae0e-10d081565c67} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiFuzzyMatchAllIndices();) 2025.06.18 11:20:57.767119 [ 35675 ] {f437e368-5f37-4200-ae0e-10d081565c67} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.791803 [ 35675 ] {70d2327d-4f5a-495b-9cff-ac70607406ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiFuzzyMatchAny();) 2025.06.18 11:20:57.795286 [ 35675 ] {70d2327d-4f5a-495b-9cff-ac70607406ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.819657 [ 35675 ] {32e8804e-255e-435e-aaa9-5a81abf06c9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiFuzzyMatchAnyIndex();) 2025.06.18 11:20:57.823312 [ 35675 ] {32e8804e-255e-435e-aaa9-5a81abf06c9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.824579 [ 35659 ] {8e455c68-2d99-45ed-8f51-7a146215a9d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmaskToArray(NULL, NULL);) 2025.06.18 11:20:57.828415 [ 35659 ] {8e455c68-2d99-45ed-8f51-7a146215a9d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.848042 [ 35675 ] {ecfe6e9c-937b-4f79-961c-da19776d32a6} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiIf();) 2025.06.18 11:20:57.851568 [ 35675 ] {ecfe6e9c-937b-4f79-961c-da19776d32a6} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.855792 [ 35659 ] {8d741653-c102-4bc6-ae59-f81d8f7a0050} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmaskToList(NULL, NULL);) 2025.06.18 11:20:57.859058 [ 35659 ] {8d741653-c102-4bc6-ae59-f81d8f7a0050} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.875220 [ 35675 ] {ec837bea-48f3-4f39-972c-64110292df28} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 0, should be 2: In scope SELECT multiMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiMatchAllIndices();) 2025.06.18 11:20:57.878706 [ 35675 ] {ec837bea-48f3-4f39-972c-64110292df28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 0, should be 2: In scope SELECT multiMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.888238 [ 35659 ] {7fb22180-6e1e-4f36-ba7f-f9fd5c37092e} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT blockNumber(NULL, NULL);) 2025.06.18 11:20:57.891648 [ 35659 ] {7fb22180-6e1e-4f36-ba7f-f9fd5c37092e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.902236 [ 35675 ] {e65945c3-fac8-406c-84f4-5517d61fe6eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 0, should be 2: In scope SELECT multiMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiMatchAny();) 2025.06.18 11:20:57.905550 [ 35675 ] {e65945c3-fac8-406c-84f4-5517d61fe6eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 0, should be 2: In scope SELECT multiMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.930476 [ 35675 ] {fcf16ec8-d006-42ac-956b-d92f99ac22e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 0, should be 2: In scope SELECT multiMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiMatchAnyIndex();) 2025.06.18 11:20:57.934289 [ 35675 ] {fcf16ec8-d006-42ac-956b-d92f99ac22e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 0, should be 2: In scope SELECT multiMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.957973 [ 35675 ] {3e8626a7-c8e1-451b-b21b-db686cd7d389} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositions(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositions();) 2025.06.18 11:20:57.961785 [ 35675 ] {3e8626a7-c8e1-451b-b21b-db686cd7d389} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositions(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.984392 [ 35659 ] {eb0ada39-6b00-4cae-923f-7c9fceb962ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT blockSize(NULL, NULL);) 2025.06.18 11:20:57.985735 [ 35675 ] {7f1dd665-9f52-4f43-958f-0569c6586a5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitive();) 2025.06.18 11:20:57.987879 [ 35659 ] {eb0ada39-6b00-4cae-923f-7c9fceb962ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:57.988967 [ 35675 ] {7f1dd665-9f52-4f43-958f-0569c6586a5d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.011575 [ 35675 ] {702ae80a-5fc3-45a6-8bfb-3c2aa8e95f42} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8();) 2025.06.18 11:20:58.014586 [ 35675 ] {702ae80a-5fc3-45a6-8bfb-3c2aa8e95f42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.036113 [ 35675 ] {e5aa7361-e9d9-45d1-bdd0-7287a3c68080} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositionsUTF8();) 2025.06.18 11:20:58.039270 [ 35675 ] {e5aa7361-e9d9-45d1-bdd0-7287a3c68080} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.063455 [ 35675 ] {95688647-0dc6-4261-ab75-ab738d1a4961} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 0, should be 2: In scope SELECT multiSearchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAny();) 2025.06.18 11:20:58.066800 [ 35675 ] {95688647-0dc6-4261-ab75-ab738d1a4961} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 0, should be 2: In scope SELECT multiSearchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.082997 [ 35659 ] {76a6b8b1-6ef5-45bd-a482-680c84cc3596} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT buildId(NULL, NULL);) 2025.06.18 11:20:58.086498 [ 35659 ] {76a6b8b1-6ef5-45bd-a482-680c84cc3596} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.090403 [ 35675 ] {32807f6c-5ee7-4f5f-a4a6-31a15b0f5c33} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAnyCaseInsensitive();) 2025.06.18 11:20:58.094179 [ 35675 ] {32807f6c-5ee7-4f5f-a4a6-31a15b0f5c33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.111212 [ 35636 ] {f2bed2ab-5542-4a2a-a1b7-721506e89ea4} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaM2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaM2(100). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37680) (comment: 01074_h3_range_check.sql) (in query: SELECT h3HexAreaM2(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3HexAreaM2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001236c3de 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:58.113131 [ 35636 ] {f2bed2ab-5542-4a2a-a1b7-721506e89ea4} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaM2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaM2(100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3HexAreaM2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001236c3de 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:58.117191 [ 35675 ] {f4a2c53c-2082-413b-a5c1-4c92b15ebc93} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8();) 2025.06.18 11:20:58.120258 [ 35675 ] {f4a2c53c-2082-413b-a5c1-4c92b15ebc93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.140134 [ 35675 ] {61cf0804-fdd5-4c66-952c-f643ccb527b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAnyUTF8();) 2025.06.18 11:20:58.142941 [ 35675 ] {61cf0804-fdd5-4c66-952c-f643ccb527b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.163089 [ 35675 ] {d561aff5-93e9-4994-820b-3d287850fe98} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndex();) 2025.06.18 11:20:58.166053 [ 35675 ] {d561aff5-93e9-4994-820b-3d287850fe98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.191174 [ 35675 ] {bdb77a16-3a4d-48d3-8102-eea972e56a00} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitive();) 2025.06.18 11:20:58.194521 [ 35675 ] {bdb77a16-3a4d-48d3-8102-eea972e56a00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.217089 [ 35675 ] {71926424-3696-4716-b499-0ffbdee8dab1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8();) 2025.06.18 11:20:58.220211 [ 35675 ] {71926424-3696-4716-b499-0ffbdee8dab1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.243190 [ 35675 ] {9d77f172-5ca0-4c0d-ad09-fec639399577} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndexUTF8();) 2025.06.18 11:20:58.246921 [ 35675 ] {9d77f172-5ca0-4c0d-ad09-fec639399577} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.270873 [ 35675 ] {fb8d1203-a573-4ddd-bace-a7b679dd8036} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPosition(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPosition();) 2025.06.18 11:20:58.274344 [ 35675 ] {fb8d1203-a573-4ddd-bace-a7b679dd8036} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPosition(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.286560 [ 35659 ] {7cfb3ff6-7a89-4d3f-b122-278efb32b7f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT byteSwap(NULL, NULL);) 2025.06.18 11:20:58.291015 [ 35659 ] {7cfb3ff6-7a89-4d3f-b122-278efb32b7f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.297201 [ 35675 ] {e8b1d82a-c769-475f-9b75-f432eb742472} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitive();) 2025.06.18 11:20:58.300230 [ 35675 ] {e8b1d82a-c769-475f-9b75-f432eb742472} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.322271 [ 35675 ] {33e7d918-f260-4468-aa57-1228aed62a0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8();) 2025.06.18 11:20:58.325769 [ 35675 ] {33e7d918-f260-4468-aa57-1228aed62a0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.349847 [ 35675 ] {4f55e255-c855-430e-9377-81c33ce4bcf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPositionUTF8();) 2025.06.18 11:20:58.353458 [ 35675 ] {4f55e255-c855-430e-9377-81c33ce4bcf5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.377243 [ 35675 ] {ee6ac218-05b7-4007-a329-1eaa6ea57890} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT multiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiply();) 2025.06.18 11:20:58.380724 [ 35675 ] {ee6ac218-05b7-4007-a329-1eaa6ea57890} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT multiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.404248 [ 35675 ] {0dbb19bf-0d5f-4b79-8ef1-29f2c059051a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiplyDecimal();) 2025.06.18 11:20:58.407835 [ 35675 ] {0dbb19bf-0d5f-4b79-8ef1-29f2c059051a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.439162 [ 35659 ] {6f0eb2a6-e7a9-4318-9641-d66849b95cc4} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT caseWithoutExpr(NULL, NULL);) 2025.06.18 11:20:58.442555 [ 35659 ] {6f0eb2a6-e7a9-4318-9641-d66849b95cc4} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.471564 [ 35659 ] {97a126bc-8888-4ec1-8a37-84de23825b5a} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT caseWithoutExpression(NULL, NULL);) 2025.06.18 11:20:58.474891 [ 35659 ] {97a126bc-8888-4ec1-8a37-84de23825b5a} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.504485 [ 35659 ] {9805ca2c-9ca6-4e2d-898f-7b708f369323} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT catboostEvaluate(NULL, NULL);) 2025.06.18 11:20:58.508303 [ 35659 ] {9805ca2c-9ca6-4e2d-898f-7b708f369323} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:58.537223 [ 35659 ] {7bba3eb2-3b51-4aeb-aef1-aa234090f0d7} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT categoricalInformationValue(NULL, NULL);) 2025.06.18 11:20:58.540625 [ 35659 ] {7bba3eb2-3b51-4aeb-aef1-aa234090f0d7} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:20:58.567709 [ 35659 ] {102587e5-d452-4e78-98c1-eba11746387e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cbrt(NULL, NULL);) 2025.06.18 11:20:58.571133 [ 35659 ] {102587e5-d452-4e78-98c1-eba11746387e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.644258 [ 35675 ] {9c08aba9-0574-42f2-b61d-d5a4fe0873dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 0, should be 1: In scope SELECT negate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT negate();) 2025.06.18 11:20:58.647602 [ 35675 ] {9c08aba9-0574-42f2-b61d-d5a4fe0873dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 0, should be 1: In scope SELECT negate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.668687 [ 35675 ] {a783f100-1f75-4ad7-af05-aa0cb42fc5bb} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT neighbor();) 2025.06.18 11:20:58.671954 [ 35675 ] {a783f100-1f75-4ad7-af05-aa0cb42fc5bb} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:20:58.691441 [ 35675 ] {e7d1990b-c996-4ca2-b041-0e6ac68d68a5} executeQuery: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 0, should be at least 2: In scope SELECT nested(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nested();) 2025.06.18 11:20:58.694551 [ 35675 ] {e7d1990b-c996-4ca2-b041-0e6ac68d68a5} TCPHandler: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 0, should be at least 2: In scope SELECT nested(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:58.713046 [ 35675 ] {f6e077b8-52cb-4f86-bcc3-bb06f5ed70d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 0, should be 1: In scope SELECT netloc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT netloc();) 2025.06.18 11:20:58.715998 [ 35675 ] {f6e077b8-52cb-4f86-bcc3-bb06f5ed70d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 0, should be 1: In scope SELECT netloc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.736575 [ 35675 ] {5d9be01b-9391-460c-98ab-82dc081fc98a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 0, should be 2: In scope SELECT ngramDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistance();) 2025.06.18 11:20:58.739642 [ 35675 ] {5d9be01b-9391-460c-98ab-82dc081fc98a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 0, should be 2: In scope SELECT ngramDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.762054 [ 35675 ] {e5cf60a3-2e3f-408a-a2e5-29fed21b836f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistanceCaseInsensitive();) 2025.06.18 11:20:58.765754 [ 35675 ] {e5cf60a3-2e3f-408a-a2e5-29fed21b836f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.786232 [ 35675 ] {edcd740c-3000-48f1-8ce2-2e53ccff2f47} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistanceCaseInsensitiveUTF8();) 2025.06.18 11:20:58.789531 [ 35675 ] {edcd740c-3000-48f1-8ce2-2e53ccff2f47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.811840 [ 35675 ] {833d5f64-c8aa-46f7-aa62-f622d93d23a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistanceUTF8();) 2025.06.18 11:20:58.815188 [ 35675 ] {833d5f64-c8aa-46f7-aa62-f622d93d23a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:58.837871 [ 35675 ] {a712f331-8084-4ca9-aa11-aeae17991a4a} executeQuery: Code: 35. DB::Exception: Function ngramMinHash expect at least one argument: In scope SELECT ngramMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHash();) 2025.06.18 11:20:58.841231 [ 35675 ] {a712f331-8084-4ca9-aa11-aeae17991a4a} TCPHandler: Code: 35. DB::Exception: Function ngramMinHash expect at least one argument: In scope SELECT ngramMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:58.863599 [ 35675 ] {01a7024d-24fe-470e-9692-2e40d49084e5} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArg expect at least one argument: In scope SELECT ngramMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArg();) 2025.06.18 11:20:58.866911 [ 35675 ] {01a7024d-24fe-470e-9692-2e40d49084e5} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArg expect at least one argument: In scope SELECT ngramMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:58.890806 [ 35675 ] {a7a32fc3-4a8d-420a-a86e-a4ba615c88a7} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArgCaseInsensitive();) 2025.06.18 11:20:58.895452 [ 35675 ] {a7a32fc3-4a8d-420a-a86e-a4ba615c88a7} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:58.902949 [ 35636 ] {f59d97d8-0498-4cc3-af77-505580fd80ce} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaKm2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaKm2(100). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37680) (comment: 01074_h3_range_check.sql) (in query: SELECT h3HexAreaKm2(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3HexAreaKm2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012369dce 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:58.905109 [ 35636 ] {f59d97d8-0498-4cc3-af77-505580fd80ce} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaKm2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaKm2(100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3HexAreaKm2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012369dce 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:20:58.919851 [ 35675 ] {e8bd1265-5e9d-4669-86cf-b6fa5493b53c} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8();) 2025.06.18 11:20:58.923575 [ 35675 ] {e8bd1265-5e9d-4669-86cf-b6fa5493b53c} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:58.947182 [ 35675 ] {e1a513c1-c238-4d32-b07d-faa69226f289} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgUTF8 expect at least one argument: In scope SELECT ngramMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArgUTF8();) 2025.06.18 11:20:58.950731 [ 35675 ] {e1a513c1-c238-4d32-b07d-faa69226f289} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgUTF8 expect at least one argument: In scope SELECT ngramMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:58.973670 [ 35675 ] {9f548d55-3f9b-458c-a43f-e35d8bffd04b} executeQuery: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashCaseInsensitive();) 2025.06.18 11:20:58.977108 [ 35675 ] {9f548d55-3f9b-458c-a43f-e35d8bffd04b} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:59.003290 [ 35675 ] {52bc3c86-358c-4bfe-bfd5-f0fd6fbdf49b} executeQuery: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashCaseInsensitiveUTF8();) 2025.06.18 11:20:59.009103 [ 35675 ] {52bc3c86-358c-4bfe-bfd5-f0fd6fbdf49b} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:59.034507 [ 35675 ] {c97b6587-4b94-4df1-b55f-b4237fbe6a2b} executeQuery: Code: 35. DB::Exception: Function ngramMinHashUTF8 expect at least one argument: In scope SELECT ngramMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashUTF8();) 2025.06.18 11:20:59.038065 [ 35675 ] {c97b6587-4b94-4df1-b55f-b4237fbe6a2b} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashUTF8 expect at least one argument: In scope SELECT ngramMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:59.063103 [ 35675 ] {179ea209-55bc-4c44-92e5-45b3cf1decef} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 0, should be 2: In scope SELECT ngramSearch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearch();) 2025.06.18 11:20:59.066572 [ 35675 ] {179ea209-55bc-4c44-92e5-45b3cf1decef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 0, should be 2: In scope SELECT ngramSearch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.089538 [ 35675 ] {80c5ad28-36b4-4021-9096-e7c8f21cea3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearchCaseInsensitive();) 2025.06.18 11:20:59.093184 [ 35675 ] {80c5ad28-36b4-4021-9096-e7c8f21cea3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.116368 [ 35675 ] {7875b428-9164-4a90-a8a3-9145d0630689} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearchCaseInsensitiveUTF8();) 2025.06.18 11:20:59.119653 [ 35675 ] {7875b428-9164-4a90-a8a3-9145d0630689} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.133357 [ 35659 ] {3915cdd0-acff-4928-b4c1-6d57b68e3f48} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT clamp(NULL, NULL);) 2025.06.18 11:20:59.137516 [ 35659 ] {3915cdd0-acff-4928-b4c1-6d57b68e3f48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.142069 [ 35675 ] {6110f6c7-eeb6-42a6-99d4-d76e858a0aac} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearchUTF8();) 2025.06.18 11:20:59.145330 [ 35675 ] {6110f6c7-eeb6-42a6-99d4-d76e858a0aac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.167486 [ 35675 ] {2b7d5abe-3683-48bd-b6c8-3a925d1ae08d} executeQuery: Code: 35. DB::Exception: Function ngramSimHash expect at least one argument: In scope SELECT ngramSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHash();) 2025.06.18 11:20:59.170884 [ 35675 ] {2b7d5abe-3683-48bd-b6c8-3a925d1ae08d} TCPHandler: Code: 35. DB::Exception: Function ngramSimHash expect at least one argument: In scope SELECT ngramSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:59.194544 [ 35675 ] {814edf7c-93fe-4bf9-bc62-cd9412f408ec} executeQuery: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitive expect at least one argument: In scope SELECT ngramSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHashCaseInsensitive();) 2025.06.18 11:20:59.198160 [ 35675 ] {814edf7c-93fe-4bf9-bc62-cd9412f408ec} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitive expect at least one argument: In scope SELECT ngramSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:59.221844 [ 35675 ] {0aa1594b-a968-479a-81fb-c5dfff3a3308} executeQuery: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHashCaseInsensitiveUTF8();) 2025.06.18 11:20:59.225340 [ 35675 ] {0aa1594b-a968-479a-81fb-c5dfff3a3308} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:59.248110 [ 35675 ] {d95efdf7-6cee-4baf-a131-e0b2b8b055b1} executeQuery: Code: 35. DB::Exception: Function ngramSimHashUTF8 expect at least one argument: In scope SELECT ngramSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHashUTF8();) 2025.06.18 11:20:59.251398 [ 35675 ] {d95efdf7-6cee-4baf-a131-e0b2b8b055b1} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashUTF8 expect at least one argument: In scope SELECT ngramSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:20:59.273791 [ 35675 ] {85931c17-cd0b-495d-8aed-62fa57355d70} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 0, should be 2: In scope SELECT ngrams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngrams();) 2025.06.18 11:20:59.277258 [ 35675 ] {85931c17-cd0b-495d-8aed-62fa57355d70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 0, should be 2: In scope SELECT ngrams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.299845 [ 35675 ] {ecded3b4-3696-48cc-a9ab-fe24d4d7a876} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nonNegativeDerivative();) 2025.06.18 11:20:59.302989 [ 35675 ] {ecded3b4-3696-48cc-a9ab-fe24d4d7a876} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.324766 [ 35675 ] {4ea5b5ae-f937-454d-b1ed-d12870fabbd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT normL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normL1();) 2025.06.18 11:20:59.328032 [ 35675 ] {4ea5b5ae-f937-454d-b1ed-d12870fabbd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT normL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.350615 [ 35675 ] {11688d99-f987-410a-9672-3ac466b1f5ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT normL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normL2();) 2025.06.18 11:20:59.353964 [ 35675 ] {11688d99-f987-410a-9672-3ac466b1f5ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT normL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.376538 [ 35675 ] {7674f844-9839-43af-8ce4-56020832c340} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT normL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normL2Squared();) 2025.06.18 11:20:59.380304 [ 35675 ] {7674f844-9839-43af-8ce4-56020832c340} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT normL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.402728 [ 35675 ] {7358b37e-834c-4430-97cd-40bbc553959c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT normLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normLinf();) 2025.06.18 11:20:59.406091 [ 35675 ] {7358b37e-834c-4430-97cd-40bbc553959c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT normLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.427803 [ 35675 ] {ce4a06c8-a525-4131-a68d-eb4a5945eb31} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT normLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normLp();) 2025.06.18 11:20:59.431052 [ 35675 ] {ce4a06c8-a525-4131-a68d-eb4a5945eb31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT normLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.453475 [ 35675 ] {49b0d983-c782-4964-9628-070639b17d89} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeL1();) 2025.06.18 11:20:59.456693 [ 35675 ] {49b0d983-c782-4964-9628-070639b17d89} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.479927 [ 35675 ] {c304494a-810b-43f0-a418-c086eb44050b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeL2();) 2025.06.18 11:20:59.483224 [ 35675 ] {c304494a-810b-43f0-a418-c086eb44050b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.487967 [ 35659 ] {0adc6b42-9926-446f-aebe-d97e5462317c} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT connectionId(NULL, NULL);) 2025.06.18 11:20:59.490826 [ 35659 ] {0adc6b42-9926-446f-aebe-d97e5462317c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.505848 [ 35675 ] {dc24e260-e2d3-45bf-85ae-3c67f5a43683} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT normalizeLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeLinf();) 2025.06.18 11:20:59.509170 [ 35675 ] {dc24e260-e2d3-45bf-85ae-3c67f5a43683} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT normalizeLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.519798 [ 35659 ] {27b79670-4dd0-4da0-a499-31e4eed9db01} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT connection_id(NULL, NULL);) 2025.06.18 11:20:59.522980 [ 35659 ] {27b79670-4dd0-4da0-a499-31e4eed9db01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.531440 [ 35675 ] {e02b5df6-eb62-493a-9d7f-4f731b43a84b} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT normalizeLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeLp();) 2025.06.18 11:20:59.534677 [ 35675 ] {e02b5df6-eb62-493a-9d7f-4f731b43a84b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT normalizeLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.555733 [ 35675 ] {6f7f8b3f-5a7a-4fdd-ac05-2eeb6e74a1c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 0, should be 1: In scope SELECT normalizeQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeQuery();) 2025.06.18 11:20:59.559133 [ 35675 ] {6f7f8b3f-5a7a-4fdd-ac05-2eeb6e74a1c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 0, should be 1: In scope SELECT normalizeQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.584933 [ 35675 ] {9f6dc1bd-5279-4d53-b2e8-e5b1ab895e41} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizeQueryKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeQueryKeepNames();) 2025.06.18 11:20:59.588432 [ 35675 ] {9f6dc1bd-5279-4d53-b2e8-e5b1ab895e41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizeQueryKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.611367 [ 35675 ] {7ad3b479-1a47-4f27-894b-5be86777fbd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFC();) 2025.06.18 11:20:59.614542 [ 35675 ] {7ad3b479-1a47-4f27-894b-5be86777fbd2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.619303 [ 35659 ] {80e538b7-75a0-4470-92d6-f3865f15b81c} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT convertCharset(NULL, NULL);) 2025.06.18 11:20:59.623246 [ 35659 ] {80e538b7-75a0-4470-92d6-f3865f15b81c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.637733 [ 35675 ] {a950331a-76fc-458a-a72e-72927879695e} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFD();) 2025.06.18 11:20:59.641047 [ 35675 ] {a950331a-76fc-458a-a72e-72927879695e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.664334 [ 35675 ] {a046a499-7537-4e7c-8216-7a180e6cdf70} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFKC();) 2025.06.18 11:20:59.667920 [ 35675 ] {a046a499-7537-4e7c-8216-7a180e6cdf70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.691056 [ 35675 ] {936d5084-7481-4980-9ea6-998af8a7ba01} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFKD();) 2025.06.18 11:20:59.694985 [ 35675 ] {936d5084-7481-4980-9ea6-998af8a7ba01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.717674 [ 35675 ] {313a8a58-61b8-469d-b572-87aa61794463} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizedQueryHash();) 2025.06.18 11:20:59.721420 [ 35675 ] {313a8a58-61b8-469d-b572-87aa61794463} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.745570 [ 35675 ] {56d29865-8d12-4c34-8eb6-725f2f043e40} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHashKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizedQueryHashKeepNames();) 2025.06.18 11:20:59.760598 [ 35669 ] {2aa70d9c-4bae-4cf5-9b56-c84a5f77023c} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1048577 ('-'): -. Max query size exceeded: '-'. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49860) (in query: select 1 in (1, 1, ... (truncated 948624 characters)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:59.802836 [ 35675 ] {56d29865-8d12-4c34-8eb6-725f2f043e40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHashKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.803039 [ 35669 ] {2aa70d9c-4bae-4cf5-9b56-c84a5f77023c} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1048577 ('-'): -. Max query size exceeded: '-'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:20:59.825953 [ 35675 ] {3f16b0cf-c0eb-457b-a6f8-720b5e474f6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 0, should be 1: In scope SELECT not(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT not();) 2025.06.18 11:20:59.829467 [ 35675 ] {3f16b0cf-c0eb-457b-a6f8-720b5e474f6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 0, should be 1: In scope SELECT not(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.853955 [ 35675 ] {c8c6ffc3-3daa-4d96-b938-ab4a1bf8a03d} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 0, should be 1: In scope SELECT notEmpty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notEmpty();) 2025.06.18 11:20:59.857437 [ 35675 ] {c8c6ffc3-3daa-4d96-b938-ab4a1bf8a03d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 0, should be 1: In scope SELECT notEmpty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.882532 [ 35675 ] {414a4f8c-0c17-49f4-9b80-bb2116a6630c} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 0, should be 2: In scope SELECT notEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notEquals();) 2025.06.18 11:20:59.886170 [ 35675 ] {414a4f8c-0c17-49f4-9b80-bb2116a6630c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 0, should be 2: In scope SELECT notEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.905754 [ 35659 ] {ce5ace20-09b1-4530-8d01-a502d24d3e3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cos(NULL, NULL);) 2025.06.18 11:20:59.909306 [ 35659 ] {ce5ace20-09b1-4530-8d01-a502d24d3e3a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.911197 [ 35675 ] {d3122afe-227c-4e90-a636-3c112b5870e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 0, should be 2: In scope SELECT notILike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notILike();) 2025.06.18 11:20:59.914756 [ 35675 ] {d3122afe-227c-4e90-a636-3c112b5870e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 0, should be 2: In scope SELECT notILike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.920220 [ 1590 ] {229a0a4e-deb3-49d3-b0ae-06592a42c760} executeQuery: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37774) (comment: 00936_function_result_with_operator_in.sql) (in query: -- non-constant expressions in the right side of IN SELECT count() FROM samples WHERE 1 IN range(samples.value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Planner/CollectSets.cpp:106: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000033608d98 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000336049d1 6. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003360486b 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf5645 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:59.922690 [ 1590 ] {229a0a4e-deb3-49d3-b0ae-06592a42c760} TCPHandler: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Planner/CollectSets.cpp:106: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000033608d98 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000336049d1 6. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003360486b 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf5645 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:59.939250 [ 35675 ] {2ffb65fe-87ed-4c8b-8594-ee53f1919007} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notIn();) 2025.06.18 11:20:59.939769 [ 35659 ] {e5a7fffc-d602-4c14-a666-9ac6ef13244b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cosh(NULL, NULL);) 2025.06.18 11:20:59.942627 [ 35675 ] {2ffb65fe-87ed-4c8b-8594-ee53f1919007} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.943528 [ 35659 ] {e5a7fffc-d602-4c14-a666-9ac6ef13244b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.963471 [ 1590 ] {539631ac-d217-4e62-99e7-138d8d442cf2} executeQuery: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37774) (comment: 00936_function_result_with_operator_in.sql) (in query: SELECT count() FROM samples WHERE 1 IN range(rand() % 1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Planner/CollectSets.cpp:106: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000033608d98 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000336049d1 6. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003360486b 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf5645 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:59.965578 [ 35675 ] {811a6db0-fba7-4703-a177-6aaee2c41a0f} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notInIgnoreSet();) 2025.06.18 11:20:59.965747 [ 1590 ] {539631ac-d217-4e62-99e7-138d8d442cf2} TCPHandler: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Planner/CollectSets.cpp:106: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000033608d98 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000336049d1 6. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003360486b 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf5645 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:20:59.968843 [ 35675 ] {811a6db0-fba7-4703-a177-6aaee2c41a0f} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:20:59.993377 [ 35675 ] {4fb72d0f-dc55-46bd-a966-4a0f50a9db42} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 0, should be 2: In scope SELECT notLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notLike();) 2025.06.18 11:20:59.997058 [ 35675 ] {4fb72d0f-dc55-46bd-a966-4a0f50a9db42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 0, should be 2: In scope SELECT notLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.020837 [ 35675 ] {2d283c0b-ecb0-4484-91ed-e219728b56a3} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notNullIn();) 2025.06.18 11:21:00.024539 [ 35675 ] {2d283c0b-ecb0-4484-91ed-e219728b56a3} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.026346 [ 35659 ] {4c9cae87-a727-4ed3-9bf9-1c03e8a7f2a9} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT count(NULL, NULL);) 2025.06.18 11:21:00.029855 [ 35659 ] {4c9cae87-a727-4ed3-9bf9-1c03e8a7f2a9} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.032014 [ 1590 ] {7440ceea-74f6-4f56-a414-ae7451e7a861} executeQuery: Code: 277. DB::Exception: Primary key (key) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37774) (comment: 00936_function_result_with_operator_in.sql) (in query: -- index is not used SELECT count() FROM samples WHERE value IN range(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:00.034186 [ 1590 ] {7440ceea-74f6-4f56-a414-ae7451e7a861} TCPHandler: Code: 277. DB::Exception: Primary key (key) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003840498a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003befd847 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003befc2fa 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003befba85 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17f729 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:00.048371 [ 35675 ] {70913fab-8adc-4bc4-b18e-ef1f385a59fe} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notNullInIgnoreSet();) 2025.06.18 11:21:00.052705 [ 35675 ] {70913fab-8adc-4bc4-b18e-ef1f385a59fe} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.058644 [ 35659 ] {b90b5b61-db22-470f-b6e1-2c7f91c4e26d} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT countDigits(NULL, NULL);) 2025.06.18 11:21:00.062347 [ 35659 ] {b90b5b61-db22-470f-b6e1-2c7f91c4e26d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.091213 [ 35659 ] {e7aaa52d-0366-42cb-aa5a-9dab0a906976} executeQuery: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT countEqual(NULL, NULL);) 2025.06.18 11:21:00.094579 [ 35659 ] {e7aaa52d-0366-42cb-aa5a-9dab0a906976} TCPHandler: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:00.378758 [ 35675 ] {a37d3fcb-88c7-4293-a328-fdbc915807d8} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nth_value();) 2025.06.18 11:21:00.382087 [ 35675 ] {a37d3fcb-88c7-4293-a328-fdbc915807d8} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.404713 [ 35675 ] {b0eda92f-5eea-4243-ae84-782bbe1bef2e} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ntile();) 2025.06.18 11:21:00.408274 [ 35675 ] {b0eda92f-5eea-4243-ae84-782bbe1bef2e} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.431196 [ 35675 ] {45c89e19-cc12-4fb8-b0ca-522a657139a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 0, should be 2: In scope SELECT nullIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nullIf();) 2025.06.18 11:21:00.434536 [ 35675 ] {45c89e19-cc12-4fb8-b0ca-522a657139a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 0, should be 2: In scope SELECT nullIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.457267 [ 35675 ] {9b355f6a-68c1-43d1-a6a5-c4120770ab48} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nullIn();) 2025.06.18 11:21:00.460750 [ 35675 ] {9b355f6a-68c1-43d1-a6a5-c4120770ab48} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.483082 [ 35675 ] {1b8ff5f8-f14b-431a-a660-18a05fb1336d} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nullInIgnoreSet();) 2025.06.18 11:21:00.486386 [ 35675 ] {1b8ff5f8-f14b-431a-a660-18a05fb1336d} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.509342 [ 35675 ] {de3d25b7-b1ad-4ee7-a77d-bb7568862a51} executeQuery: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 0: In scope SELECT or(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT or();) 2025.06.18 11:21:00.512691 [ 35675 ] {de3d25b7-b1ad-4ee7-a77d-bb7568862a51} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 0: In scope SELECT or(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:00.536527 [ 35675 ] {2ed6e001-0890-465e-ba1c-80b1d265712e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime();) 2025.06.18 11:21:00.539829 [ 35675 ] {2ed6e001-0890-465e-ba1c-80b1d265712e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.562061 [ 35675 ] {77e27f13-b11b-48be-b0f6-7836ea5555b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime32BestEffort();) 2025.06.18 11:21:00.565423 [ 35675 ] {77e27f13-b11b-48be-b0f6-7836ea5555b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.589005 [ 35675 ] {009ac74c-8e56-4e52-a0bf-0d9a4c5c94ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime32BestEffortOrNull();) 2025.06.18 11:21:00.592574 [ 35675 ] {009ac74c-8e56-4e52-a0bf-0d9a4c5c94ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.616468 [ 35675 ] {b68d1e3b-bf69-422f-aede-8130008f8938} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime32BestEffortOrZero();) 2025.06.18 11:21:00.620021 [ 35675 ] {b68d1e3b-bf69-422f-aede-8130008f8938} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.644440 [ 35675 ] {cfd0a98d-cf76-4f0a-b5bd-135d9bd6314f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffort'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffort();) 2025.06.18 11:21:00.648301 [ 35675 ] {cfd0a98d-cf76-4f0a-b5bd-135d9bd6314f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffort'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.670692 [ 35675 ] {adfdb190-3abe-42ee-a8ea-8ce283a6a3f2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortOrNull();) 2025.06.18 11:21:00.674153 [ 35675 ] {adfdb190-3abe-42ee-a8ea-8ce283a6a3f2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.688336 [ 1590 ] {02161584-c659-49e0-92d6-ddaa3bcde789} executeQuery: Code: 53. DB::Exception: Cannot convert string 'ab' to type UInt8. (TYPE_MISMATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37774) (comment: 00936_function_result_with_operator_in.sql) (in query: -- wrong type SELECT 123 IN splitByChar('c', 'abcdef');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357c6d05 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x00000000335e2875 8. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x00000000335dd55f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a160e 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:21:00.690412 [ 1590 ] {02161584-c659-49e0-92d6-ddaa3bcde789} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'ab' to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4c3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c5ab0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357c6d05 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x00000000335e2875 8. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x00000000335dd55f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a160e 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:21:00.697947 [ 35675 ] {fa2646c4-65ac-406d-8c22-115f86716213} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortOrZero();) 2025.06.18 11:21:00.701454 [ 35675 ] {fa2646c4-65ac-406d-8c22-115f86716213} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.725243 [ 35675 ] {db511df1-1278-408c-99ed-655ab0be718d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUS'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortUS();) 2025.06.18 11:21:00.728783 [ 35675 ] {db511df1-1278-408c-99ed-655ab0be718d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUS'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.753149 [ 35675 ] {7a414da6-7c70-49ea-a65a-ff9ecb5b8c05} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortUSOrNull();) 2025.06.18 11:21:00.756954 [ 35675 ] {7a414da6-7c70-49ea-a65a-ff9ecb5b8c05} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.783576 [ 35675 ] {66116a5e-9d63-48ff-ba60-2faeeea3345a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortUSOrZero();) 2025.06.18 11:21:00.787370 [ 35675 ] {66116a5e-9d63-48ff-ba60-2faeeea3345a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.811844 [ 35675 ] {3ff83fbc-52ee-4a69-8843-b6fb689f7127} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffort();) 2025.06.18 11:21:00.815643 [ 35675 ] {3ff83fbc-52ee-4a69-8843-b6fb689f7127} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.839903 [ 35675 ] {cc166de7-ee6d-4a20-a440-57c8e39333a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortOrNull();) 2025.06.18 11:21:00.843438 [ 35675 ] {cc166de7-ee6d-4a20-a440-57c8e39333a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.867470 [ 35675 ] {1c9e7ab5-9037-48b8-8424-be33d032bda0} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortOrZero();) 2025.06.18 11:21:00.871049 [ 35675 ] {1c9e7ab5-9037-48b8-8424-be33d032bda0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.894619 [ 35675 ] {a9321458-7648-4773-91a2-6e0666192916} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortUS();) 2025.06.18 11:21:00.898040 [ 35675 ] {a9321458-7648-4773-91a2-6e0666192916} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.921724 [ 35675 ] {3fb071ee-dfa9-448d-997d-5fe896b99d4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortUSOrNull();) 2025.06.18 11:21:00.925630 [ 35675 ] {3fb071ee-dfa9-448d-997d-5fe896b99d4f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.941527 [ 35659 ] {55c5d1fa-ffe8-4179-8a0b-ebee12d2ecfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT curdate(NULL, NULL);) 2025.06.18 11:21:00.945116 [ 35659 ] {55c5d1fa-ffe8-4179-8a0b-ebee12d2ecfa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.949081 [ 35675 ] {d639b44f-d890-4c17-85ee-a0f04692919e} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortUSOrZero();) 2025.06.18 11:21:00.952689 [ 35675 ] {d639b44f-d890-4c17-85ee-a0f04692919e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.976733 [ 35675 ] {c3f7bed7-d3d3-48a4-b19a-4637b5964788} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeInJodaSyntax();) 2025.06.18 11:21:00.980380 [ 35675 ] {c3f7bed7-d3d3-48a4-b19a-4637b5964788} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:00.983595 [ 35659 ] {1e9c4792-cefd-41f9-9fe8-0a3a2d4cd0aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentDatabase(NULL, NULL);) 2025.06.18 11:21:00.987428 [ 35659 ] {1e9c4792-cefd-41f9-9fe8-0a3a2d4cd0aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.004923 [ 35675 ] {e838e9d8-faed-4e70-a144-f321479e4420} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrNull();) 2025.06.18 11:21:01.008398 [ 35675 ] {e838e9d8-faed-4e70-a144-f321479e4420} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.021904 [ 35659 ] {2aeb71c6-f29b-43a4-9c97-38c994ba703e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentProfiles(NULL, NULL);) 2025.06.18 11:21:01.026105 [ 35659 ] {2aeb71c6-f29b-43a4-9c97-38c994ba703e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.031918 [ 35675 ] {7aa4dc13-ef02-4b5b-adcd-5d4f3e26c645} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrZero();) 2025.06.18 11:21:01.035251 [ 35675 ] {7aa4dc13-ef02-4b5b-adcd-5d4f3e26c645} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.058531 [ 35675 ] {23cfb848-1e26-4aaf-9fed-1cb316ba44bb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeOrNull();) 2025.06.18 11:21:01.061713 [ 35659 ] {dc357be3-3ac9-4215-8ec7-bc0e97048261} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentRoles(NULL, NULL);) 2025.06.18 11:21:01.061858 [ 35675 ] {23cfb848-1e26-4aaf-9fed-1cb316ba44bb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.065502 [ 35659 ] {dc357be3-3ac9-4215-8ec7-bc0e97048261} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.085100 [ 35675 ] {9cf6bea5-cede-4bd9-9df6-1d4439f63c0d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeOrZero();) 2025.06.18 11:21:01.088477 [ 35675 ] {9cf6bea5-cede-4bd9-9df6-1d4439f63c0d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.097274 [ 35659 ] {79d055c8-8ee8-4b45-99fd-e9c141698e6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentSchemas(NULL, NULL);) 2025.06.18 11:21:01.101116 [ 35659 ] {79d055c8-8ee8-4b45-99fd-e9c141698e6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.111264 [ 35675 ] {119e9c44-ee7c-4eec-bf79-f7ee44fe26a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseReadableSize();) 2025.06.18 11:21:01.114593 [ 35675 ] {119e9c44-ee7c-4eec-bf79-f7ee44fe26a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.133544 [ 35659 ] {118da4a8-b976-4d9c-be84-5b1db31b80db} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentUser(NULL, NULL);) 2025.06.18 11:21:01.137374 [ 35659 ] {118da4a8-b976-4d9c-be84-5b1db31b80db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.137593 [ 35675 ] {58636012-c13f-4482-9293-79983b5343ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseReadableSizeOrNull();) 2025.06.18 11:21:01.141093 [ 35675 ] {58636012-c13f-4482-9293-79983b5343ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.165382 [ 35675 ] {40768182-b11b-475f-9426-b67495241149} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseReadableSizeOrZero();) 2025.06.18 11:21:01.168671 [ 35675 ] {40768182-b11b-475f-9426-b67495241149} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.169796 [ 35659 ] {568c0e24-2cad-4fad-a0a5-6d9a896f731a} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_database(NULL, NULL);) 2025.06.18 11:21:01.173428 [ 35659 ] {568c0e24-2cad-4fad-a0a5-6d9a896f731a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.190692 [ 35675 ] {677582ef-8ab4-4188-8584-17a02b50ea53} executeQuery: Code: 35. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 0, should be 1.: In scope SELECT parseTimeDelta(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseTimeDelta();) 2025.06.18 11:21:01.193727 [ 35675 ] {677582ef-8ab4-4188-8584-17a02b50ea53} TCPHandler: Code: 35. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 0, should be 1.: In scope SELECT parseTimeDelta(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:01.207502 [ 35659 ] {ad6c74bf-0967-46ee-97c7-0339e71d737a} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_date(NULL, NULL);) 2025.06.18 11:21:01.211007 [ 35659 ] {ad6c74bf-0967-46ee-97c7-0339e71d737a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.215239 [ 35675 ] {b6964da8-0a45-49d3-9b5a-49b39ec67bfb} executeQuery: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT partitionID();) 2025.06.18 11:21:01.218574 [ 35675 ] {b6964da8-0a45-49d3-9b5a-49b39ec67bfb} TCPHandler: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.239658 [ 35673 ] {1495fd6f-0f19-49fb-ab85-a49265c2d7ff} executeQuery: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37824) (comment: 03305_fix_kafka_table_with_kw_arguments.sql) (in query: CREATE TABLE default.test ( `id` UInt32, `message` String ) ENGINE = Kafka(a = '1', 'clickhouse');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000038d27407 5. ./build_docker/./src/Storages/Kafka/StorageKafkaUtils.cpp:0: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000003091ccdc 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003091b1ba 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:01.242312 [ 35673 ] {1495fd6f-0f19-49fb-ab85-a49265c2d7ff} TCPHandler: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000038d27407 5. ./build_docker/./src/Storages/Kafka/StorageKafkaUtils.cpp:0: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000003091ccdc 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003091b1ba 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:01.242642 [ 35675 ] {777a1434-6bba-48ae-9c18-38ad43a19d7d} executeQuery: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionId(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT partitionId();) 2025.06.18 11:21:01.242755 [ 35659 ] {18e1aaad-8aad-49e7-93af-a9b28327574e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_schemas(NULL, NULL);) 2025.06.18 11:21:01.246007 [ 35675 ] {777a1434-6bba-48ae-9c18-38ad43a19d7d} TCPHandler: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionId(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.246322 [ 35659 ] {18e1aaad-8aad-49e7-93af-a9b28327574e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.268176 [ 35675 ] {be727bda-6373-4789-97fa-f7194f632a17} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 0, should be 1: In scope SELECT path(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT path();) 2025.06.18 11:21:01.271841 [ 35675 ] {be727bda-6373-4789-97fa-f7194f632a17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 0, should be 1: In scope SELECT path(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.276905 [ 35659 ] {05a18c7e-9afa-4f07-bc9d-12dbdc0ca283} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_timestamp(NULL, NULL);) 2025.06.18 11:21:01.280591 [ 35659 ] {05a18c7e-9afa-4f07-bc9d-12dbdc0ca283} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.294452 [ 35675 ] {1ff9f75a-ad56-49c0-8bdd-c3cf670d128c} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 0, should be 1: In scope SELECT pathFull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pathFull();) 2025.06.18 11:21:01.297751 [ 35675 ] {1ff9f75a-ad56-49c0-8bdd-c3cf670d128c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 0, should be 1: In scope SELECT pathFull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.312080 [ 35659 ] {9e90820e-85ba-4a27-87a6-e852249070a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_user(NULL, NULL);) 2025.06.18 11:21:01.316017 [ 35659 ] {9e90820e-85ba-4a27-87a6-e852249070a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.340737 [ 35675 ] {aa636eb2-86c4-4194-a9a5-8bf9254c978b} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT percentRank();) 2025.06.18 11:21:01.345428 [ 35675 ] {aa636eb2-86c4-4194-a9a5-8bf9254c978b} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:01.347478 [ 35659 ] {cfda4667-cabf-42e7-8759-143449f67f55} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutFragment(NULL, NULL);) 2025.06.18 11:21:01.351201 [ 35659 ] {cfda4667-cabf-42e7-8759-143449f67f55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.380984 [ 35659 ] {c6e51f17-babe-4dc6-b9c0-3a0e2215f7a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutIPv6(NULL, NULL);) 2025.06.18 11:21:01.384362 [ 35659 ] {c6e51f17-babe-4dc6-b9c0-3a0e2215f7a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.387535 [ 35675 ] {ab069483-b318-40cf-b8be-416bf68301c5} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT percent_rank();) 2025.06.18 11:21:01.391918 [ 35675 ] {ab069483-b318-40cf-b8be-416bf68301c5} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:01.412229 [ 35659 ] {736dd10b-8587-4265-83d0-72592b5cf3fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutQueryString(NULL, NULL);) 2025.06.18 11:21:01.415661 [ 35659 ] {736dd10b-8587-4265-83d0-72592b5cf3fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.445666 [ 35659 ] {436350c9-ddb8-40f1-9c67-d0d8c2d9bf72} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutQueryStringAndFragment(NULL, NULL);) 2025.06.18 11:21:01.449589 [ 35659 ] {436350c9-ddb8-40f1-9c67-d0d8c2d9bf72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.458058 [ 35675 ] {1e9f3791-117a-4f06-a48a-b8ac0a6824a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT plus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT plus();) 2025.06.18 11:21:01.461570 [ 35675 ] {1e9f3791-117a-4f06-a48a-b8ac0a6824a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT plus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.478610 [ 35659 ] {c5790580-17d2-452c-ae4a-017daee9742c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL);) 2025.06.18 11:21:01.482209 [ 35659 ] {c5790580-17d2-452c-ae4a-017daee9742c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.484746 [ 35675 ] {4f325431-c070-40d4-9c32-2c966cc94b70} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT pmod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pmod();) 2025.06.18 11:21:01.488148 [ 35675 ] {4f325431-c070-40d4-9c32-2c966cc94b70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT pmod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.510798 [ 35675 ] {ef23ab6a-298a-41a8-9b2f-48e32e151416} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pointInEllipses();) 2025.06.18 11:21:01.514128 [ 35675 ] {ef23ab6a-298a-41a8-9b2f-48e32e151416} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.536201 [ 35675 ] {709794ac-2844-4027-93f7-6c83f8d59a58} executeQuery: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pointInPolygon();) 2025.06.18 11:21:01.539798 [ 35675 ] {709794ac-2844-4027-93f7-6c83f8d59a58} TCPHandler: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:01.563854 [ 35675 ] {f1a0d17e-268c-4d26-acba-c61ab45bc2a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonAreaCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonAreaCartesian();) 2025.06.18 11:21:01.567380 [ 35675 ] {f1a0d17e-268c-4d26-acba-c61ab45bc2a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonAreaCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.590108 [ 35675 ] {5347c287-ce04-497f-b945-16c3627008a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonAreaSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonAreaSpherical();) 2025.06.18 11:21:01.593535 [ 35675 ] {5347c287-ce04-497f-b945-16c3627008a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonAreaSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.616983 [ 35675 ] {f41caa4f-1369-42cf-b68d-8ed5dc1c9a7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonConvexHullCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonConvexHullCartesian();) 2025.06.18 11:21:01.620577 [ 35675 ] {f41caa4f-1369-42cf-b68d-8ed5dc1c9a7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonConvexHullCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.646701 [ 35675 ] {d73d9e13-5e43-45c6-a963-981c4cff17df} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonPerimeterCartesian();) 2025.06.18 11:21:01.650415 [ 35675 ] {d73d9e13-5e43-45c6-a963-981c4cff17df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.676249 [ 35675 ] {465c5a2b-6301-4fff-9f94-df68960a57b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonPerimeterSpherical();) 2025.06.18 11:21:01.679861 [ 35675 ] {465c5a2b-6301-4fff-9f94-df68960a57b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.703800 [ 35675 ] {91a69435-a282-4adc-94af-777025ea8e16} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsDistanceCartesian();) 2025.06.18 11:21:01.707456 [ 35675 ] {91a69435-a282-4adc-94af-777025ea8e16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.731474 [ 35675 ] {caa20c2d-b209-4e72-8d4d-d94cba183018} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsDistanceSpherical();) 2025.06.18 11:21:01.735113 [ 35675 ] {caa20c2d-b209-4e72-8d4d-d94cba183018} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.744414 [ 35659 ] {87d18023-262d-4f4d-93de-df3f1896b6e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL);) 2025.06.18 11:21:01.748585 [ 35659 ] {87d18023-262d-4f4d-93de-df3f1896b6e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.759283 [ 35675 ] {f60bbf4e-ce38-454d-9c40-2fc173622c74} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsEqualsCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsEqualsCartesian();) 2025.06.18 11:21:01.762915 [ 35675 ] {f60bbf4e-ce38-454d-9c40-2fc173622c74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsEqualsCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.781226 [ 35659 ] {f77ba1a5-0991-4419-a3fe-cd009bef48ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL);) 2025.06.18 11:21:01.785314 [ 35659 ] {f77ba1a5-0991-4419-a3fe-cd009bef48ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.786065 [ 35675 ] {d34d0d40-8b4f-40db-9a87-68abd0c75eac} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsIntersectionCartesian();) 2025.06.18 11:21:01.789559 [ 35675 ] {d34d0d40-8b4f-40db-9a87-68abd0c75eac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.812258 [ 35675 ] {783e915e-6c6e-47fc-9cf1-2d048beb257f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsIntersectionSpherical();) 2025.06.18 11:21:01.815629 [ 35675 ] {783e915e-6c6e-47fc-9cf1-2d048beb257f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.818095 [ 35659 ] {49693107-75cb-4c84-9b37-43f53da3d5b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL);) 2025.06.18 11:21:01.821921 [ 35659 ] {49693107-75cb-4c84-9b37-43f53da3d5b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.839955 [ 35675 ] {718e0782-d87b-417d-86ad-f1e7a268cd22} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsSymDifferenceCartesian();) 2025.06.18 11:21:01.843705 [ 35675 ] {718e0782-d87b-417d-86ad-f1e7a268cd22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.869012 [ 35675 ] {7ab7a9fd-b7de-44d8-9f73-74307db74580} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsSymDifferenceSpherical();) 2025.06.18 11:21:01.872565 [ 35675 ] {7ab7a9fd-b7de-44d8-9f73-74307db74580} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.896456 [ 35675 ] {47d97bc3-04d0-426b-8450-78217e8e2fbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsUnionCartesian();) 2025.06.18 11:21:01.902707 [ 35675 ] {47d97bc3-04d0-426b-8450-78217e8e2fbd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.928558 [ 35675 ] {91b332b2-1255-4441-8733-9a1aa5231d76} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsUnionSpherical();) 2025.06.18 11:21:01.934001 [ 35675 ] {91b332b2-1255-4441-8733-9a1aa5231d76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.943339 [ 35659 ] {4b6fe375-55f5-4f16-be22-f0f5daa7f565} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutWWW(NULL, NULL);) 2025.06.18 11:21:01.948843 [ 35659 ] {4b6fe375-55f5-4f16-be22-f0f5daa7f565} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.958787 [ 35675 ] {02eb18a1-a82a-49fc-baee-b4a7feb0ceb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsWithinCartesian();) 2025.06.18 11:21:01.963787 [ 35675 ] {02eb18a1-a82a-49fc-baee-b4a7feb0ceb6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:01.990393 [ 35675 ] {01f953dc-e5e0-45e8-8694-aeb9ab12d1ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsWithinSpherical();) 2025.06.18 11:21:01.995913 [ 35675 ] {01f953dc-e5e0-45e8-8694-aeb9ab12d1ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.020863 [ 35675 ] {42da90fe-1861-438b-af55-94f2f69058aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 0, should be 1 or 2: In scope SELECT port(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT port();) 2025.06.18 11:21:02.024566 [ 35675 ] {42da90fe-1861-438b-af55-94f2f69058aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 0, should be 1 or 2: In scope SELECT port(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.052652 [ 35675 ] {72d04890-8a17-4183-b7d9-922043188c0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 0, should be 1 or 2: In scope SELECT portRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT portRFC();) 2025.06.18 11:21:02.056348 [ 35675 ] {72d04890-8a17-4183-b7d9-922043188c0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 0, should be 1 or 2: In scope SELECT portRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.085711 [ 35675 ] {f433ccc3-f6df-443e-8bc7-c2a277de454e} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positionCaseInsensitive();) 2025.06.18 11:21:02.089353 [ 35675 ] {f433ccc3-f6df-443e-8bc7-c2a277de454e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.116960 [ 35675 ] {c95c6ed4-09ec-45c2-ad46-c99d211d6f7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positionCaseInsensitiveUTF8();) 2025.06.18 11:21:02.121440 [ 35675 ] {c95c6ed4-09ec-45c2-ad46-c99d211d6f7b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.151042 [ 35675 ] {870901d4-803b-4f7c-8bc8-ffba30202df9} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positionUTF8();) 2025.06.18 11:21:02.155400 [ 35675 ] {870901d4-803b-4f7c-8bc8-ffba30202df9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.177960 [ 35659 ] {cd6b627a-0893-404c-ae8d-cbb3670d333c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dateTime64ToSnowflake(NULL, NULL);) 2025.06.18 11:21:02.179012 [ 35675 ] {1f290851-4266-4c7e-bbca-d35807df1805} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positiveModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positiveModulo();) 2025.06.18 11:21:02.182034 [ 35659 ] {cd6b627a-0893-404c-ae8d-cbb3670d333c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.182642 [ 35675 ] {1f290851-4266-4c7e-bbca-d35807df1805} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positiveModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.206231 [ 35675 ] {2673ff4a-d221-4e2e-9966-a18ab4273989} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positive_modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positive_modulo();) 2025.06.18 11:21:02.210767 [ 35675 ] {2673ff4a-d221-4e2e-9966-a18ab4273989} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positive_modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.238750 [ 35675 ] {76fdb4ee-feda-418f-b089-2bdf75cff2a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT pow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pow();) 2025.06.18 11:21:02.243200 [ 35675 ] {76fdb4ee-feda-418f-b089-2bdf75cff2a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT pow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.268570 [ 35675 ] {e5a15a85-c63c-4ee7-a450-00b457f131a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT power(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT power();) 2025.06.18 11:21:02.268778 [ 35659 ] {755dfc6b-9cb5-4f87-b931-b36a3b22c78c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dateTimeToSnowflake(NULL, NULL);) 2025.06.18 11:21:02.272155 [ 35675 ] {e5a15a85-c63c-4ee7-a450-00b457f131a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT power(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.272669 [ 35659 ] {755dfc6b-9cb5-4f87-b931-b36a3b22c78c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.299036 [ 35675 ] {989a4f6b-6f69-4d6e-9a6c-b95303dc84a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function printf doesn't match: passed 0, should be at least 1: In scope SELECT printf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT printf();) 2025.06.18 11:21:02.303580 [ 35675 ] {989a4f6b-6f69-4d6e-9a6c-b95303dc84a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function printf doesn't match: passed 0, should be at least 1: In scope SELECT printf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.330900 [ 35675 ] {6d337aed-e315-465b-ba62-84572928655d} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 0, should be 6: In scope SELECT proportionsZTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT proportionsZTest();) 2025.06.18 11:21:02.334727 [ 35675 ] {6d337aed-e315-465b-ba62-84572928655d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 0, should be 6: In scope SELECT proportionsZTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.360168 [ 35675 ] {8841e0b7-a58a-4d00-8a6a-0493a20ae899} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 0, should be 1: In scope SELECT protocol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT protocol();) 2025.06.18 11:21:02.363875 [ 35675 ] {8841e0b7-a58a-4d00-8a6a-0493a20ae899} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 0, should be 1: In scope SELECT protocol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.391277 [ 35675 ] {37da3d38-a09a-4cd3-a9cf-66da914c2631} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT punycodeDecode();) 2025.06.18 11:21:02.395600 [ 35675 ] {37da3d38-a09a-4cd3-a9cf-66da914c2631} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.424197 [ 35675 ] {d46bb116-7b12-43b6-809b-589f780ca5f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT punycodeEncode();) 2025.06.18 11:21:02.431479 [ 35675 ] {d46bb116-7b12-43b6-809b-589f780ca5f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.457208 [ 35675 ] {01f1a178-9aee-47a9-ac93-b309a9af65d7} executeQuery: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantile();) 2025.06.18 11:21:02.461634 [ 35675 ] {01f1a178-9aee-47a9-ac93-b309a9af65d7} TCPHandler: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:02.464277 [ 35659 ] {f2453d18-7ead-48f0-997d-bb1307535e32} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeHTMLComponent(NULL, NULL);) 2025.06.18 11:21:02.467884 [ 35659 ] {f2453d18-7ead-48f0-997d-bb1307535e32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.490279 [ 35675 ] {22b00d6a-146d-42e5-ba9f-eeca51d1eb2f} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileBFloat16();) 2025.06.18 11:21:02.494099 [ 35675 ] {22b00d6a-146d-42e5-ba9f-eeca51d1eb2f} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.496106 [ 35659 ] {a1d0681f-b8f4-48a6-b1b6-f1f923ad0b63} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeURLComponent(NULL, NULL);) 2025.06.18 11:21:02.499729 [ 35659 ] {a1d0681f-b8f4-48a6-b1b6-f1f923ad0b63} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.522227 [ 35675 ] {1a7f0abe-b9e7-46f6-883f-16dc6e261007} executeQuery: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileBFloat16Weighted();) 2025.06.18 11:21:02.526506 [ 35675 ] {1a7f0abe-b9e7-46f6-883f-16dc6e261007} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:02.527943 [ 35659 ] {324b0f52-4957-4ff5-917d-2d1ef328c860} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeURLFormComponent(NULL, NULL);) 2025.06.18 11:21:02.531485 [ 35659 ] {324b0f52-4957-4ff5-917d-2d1ef328c860} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.550959 [ 35675 ] {0901c0a0-9e66-4b4c-a25c-a56eb07620e6} executeQuery: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileDD();) 2025.06.18 11:21:02.554646 [ 35675 ] {0901c0a0-9e66-4b4c-a25c-a56eb07620e6} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:02.565067 [ 35659 ] {10419ae0-a192-4c90-840d-fa272e402f0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeXMLComponent(NULL, NULL);) 2025.06.18 11:21:02.568915 [ 35659 ] {10419ae0-a192-4c90-840d-fa272e402f0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.579619 [ 35675 ] {d8ed0c8d-80dc-4b86-ae3c-0452fae06063} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileDeterministic();) 2025.06.18 11:21:02.583684 [ 35675 ] {d8ed0c8d-80dc-4b86-ae3c-0452fae06063} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.609967 [ 35675 ] {04006ed4-8cb0-47ba-b694-bd887c2e95ee} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExact();) 2025.06.18 11:21:02.613897 [ 35675 ] {04006ed4-8cb0-47ba-b694-bd887c2e95ee} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.643067 [ 35675 ] {d4f50b27-ed09-4dc1-9967-b6d7e4866067} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactExclusive();) 2025.06.18 11:21:02.647248 [ 35675 ] {d4f50b27-ed09-4dc1-9967-b6d7e4866067} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.655133 [ 35659 ] {7cc51d9d-b1b0-457b-9712-b71a6076549a} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultProfiles(NULL, NULL);) 2025.06.18 11:21:02.658682 [ 35659 ] {7cc51d9d-b1b0-457b-9712-b71a6076549a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.671842 [ 35675 ] {d991bd60-9f6f-457b-be57-46238a4a0cc0} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactHigh();) 2025.06.18 11:21:02.675604 [ 35675 ] {d991bd60-9f6f-457b-be57-46238a4a0cc0} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:02.688245 [ 35659 ] {7959add6-e392-4572-bece-62b1db066167} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultRoles(NULL, NULL);) 2025.06.18 11:21:02.691738 [ 35659 ] {7959add6-e392-4572-bece-62b1db066167} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.700033 [ 35675 ] {95b0b789-b2a8-446f-af5b-e22e11cba85a} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactInclusive();) 2025.06.18 11:21:02.703849 [ 35675 ] {95b0b789-b2a8-446f-af5b-e22e11cba85a} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:02.721854 [ 35659 ] {683312c4-2db5-492c-8617-0f3b67707325} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultValueOfArgumentType(NULL, NULL);) 2025.06.18 11:21:02.725459 [ 35659 ] {683312c4-2db5-492c-8617-0f3b67707325} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.727767 [ 35675 ] {49b0c5b2-b069-41f0-9018-e31323f7c4c9} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactLow();) 2025.06.18 11:21:02.731340 [ 35675 ] {49b0c5b2-b069-41f0-9018-e31323f7c4c9} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.754667 [ 35675 ] {ad6b259d-cb6b-41f1-956c-2c10eb67574e} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactWeighted();) 2025.06.18 11:21:02.755652 [ 35659 ] {6f109563-5fe8-486d-b8c0-a1f0c1c9be29} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultValueOfTypeName(NULL, NULL);) 2025.06.18 11:21:02.758396 [ 35675 ] {ad6b259d-cb6b-41f1-956c-2c10eb67574e} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.759122 [ 35659 ] {6f109563-5fe8-486d-b8c0-a1f0c1c9be29} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.786705 [ 35675 ] {b41bd44d-fac6-407a-ab79-846f1d4ca967} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileGK();) 2025.06.18 11:21:02.787913 [ 35659 ] {481601b2-aad7-4b4a-bc57-e459546d55da} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT degrees(NULL, NULL);) 2025.06.18 11:21:02.790128 [ 35675 ] {b41bd44d-fac6-407a-ab79-846f1d4ca967} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.791328 [ 35659 ] {481601b2-aad7-4b4a-bc57-e459546d55da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.815056 [ 35675 ] {f631e9bf-ed8b-403c-9f0b-ca856596e284} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileInterpolatedWeighted();) 2025.06.18 11:21:02.819180 [ 35675 ] {f631e9bf-ed8b-403c-9f0b-ca856596e284} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.824378 [ 35659 ] {24aa5d9d-6d8d-46bb-bafd-36c2a12aeece} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT deltaSum(NULL, NULL);) 2025.06.18 11:21:02.828848 [ 35659 ] {24aa5d9d-6d8d-46bb-bafd-36c2a12aeece} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.843901 [ 35675 ] {8463c282-2c45-43a0-8bd1-9cf70be05eea} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTDigest();) 2025.06.18 11:21:02.847480 [ 35675 ] {8463c282-2c45-43a0-8bd1-9cf70be05eea} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.860580 [ 35659 ] {8ac47505-1553-4e35-93b1-f5bfde8e11d6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT deltaSumTimestamp(NULL, NULL);) 2025.06.18 11:21:02.864392 [ 35659 ] {8ac47505-1553-4e35-93b1-f5bfde8e11d6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:02.869994 [ 35675 ] {ca9e7528-9c2c-4bd8-a96d-06b3db4dc5b7} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTDigestWeighted();) 2025.06.18 11:21:02.873498 [ 35675 ] {ca9e7528-9c2c-4bd8-a96d-06b3db4dc5b7} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.885960 [ 612 ] {fd72edbb-92d8-46ea-a179-93a7c85cc3ac} executeQuery: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45986) (comment: 00507_array_no_params.sh) (in query: CREATE TABLE foo (a Array) Engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000032365bb0 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323619da 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a58f1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ed97 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:557: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034895f3e 9. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:02.889660 [ 612 ] {fd72edbb-92d8-46ea-a179-93a7c85cc3ac} TCPHandler: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000032365bb0 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323619da 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a58f1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ed97 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:557: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034895f3e 9. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:02.896012 [ 35659 ] {3d43393b-66c6-4167-a3fb-ec79e27fc852} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT demangle(NULL, NULL);) 2025.06.18 11:21:02.896037 [ 35675 ] {628159ba-f3c3-48b0-aed9-bbc57d383a1c} executeQuery: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTiming();) 2025.06.18 11:21:02.899474 [ 35675 ] {628159ba-f3c3-48b0-aed9-bbc57d383a1c} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:02.899691 [ 35659 ] {3d43393b-66c6-4167-a3fb-ec79e27fc852} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.922335 [ 35675 ] {a6f372ea-cc49-42e4-950e-3dafb92ddcf0} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTimingWeighted();) 2025.06.18 11:21:02.926327 [ 35675 ] {a6f372ea-cc49-42e4-950e-3dafb92ddcf0} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:02.955030 [ 35675 ] {d3ab4851-a6ea-4d1b-af24-dd78ccdf478c} executeQuery: Code: 35. DB::Exception: Aggregate function quantiles requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantiles();) 2025.06.18 11:21:02.957731 [ 35659 ] {634433d0-e6ca-4847-ad44-3ca01cb79f0f} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT denseRank(NULL, NULL);) 2025.06.18 11:21:02.970683 [ 35675 ] {d3ab4851-a6ea-4d1b-af24-dd78ccdf478c} TCPHandler: Code: 35. DB::Exception: Aggregate function quantiles requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:02.972221 [ 35659 ] {634433d0-e6ca-4847-ad44-3ca01cb79f0f} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:02.994762 [ 35675 ] {869f3142-3230-49e1-9a98-cb5a800e99de} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesBFloat16();) 2025.06.18 11:21:02.998220 [ 35675 ] {869f3142-3230-49e1-9a98-cb5a800e99de} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.023498 [ 35675 ] {637e4cd7-02bd-4aaf-9198-3844515fa9ba} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesBFloat16Weighted();) 2025.06.18 11:21:03.027940 [ 35675 ] {637e4cd7-02bd-4aaf-9198-3844515fa9ba} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:03.037759 [ 35659 ] {c5c918cb-1295-440d-bb18-ae51a9f1d239} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dense_rank(NULL, NULL);) 2025.06.18 11:21:03.043385 [ 35659 ] {c5c918cb-1295-440d-bb18-ae51a9f1d239} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:03.052758 [ 35675 ] {22bf1b17-00d0-46ff-ab75-04894c23265b} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesDD();) 2025.06.18 11:21:03.056669 [ 35675 ] {22bf1b17-00d0-46ff-ab75-04894c23265b} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:03.075548 [ 35659 ] {9eb6f99d-8679-4c4f-a790-a94c81707620} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectCharset(NULL, NULL);) 2025.06.18 11:21:03.079169 [ 35659 ] {9eb6f99d-8679-4c4f-a790-a94c81707620} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:03.081644 [ 35675 ] {f2909a5d-d29e-4356-ba7f-ed59069277b3} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesDeterministic();) 2025.06.18 11:21:03.085126 [ 35675 ] {f2909a5d-d29e-4356-ba7f-ed59069277b3} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.112010 [ 35675 ] {86c736a2-be56-48d9-8160-51ff8456dffa} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExact();) 2025.06.18 11:21:03.112527 [ 35659 ] {45b68d3b-d77c-4159-8b69-7dc74fffe72d} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectLanguage(NULL, NULL);) 2025.06.18 11:21:03.115914 [ 35675 ] {86c736a2-be56-48d9-8160-51ff8456dffa} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.117070 [ 35659 ] {45b68d3b-d77c-4159-8b69-7dc74fffe72d} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:03.142778 [ 35675 ] {f0cd5cf5-951e-4744-96ff-906aea07d2e7} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactExclusive();) 2025.06.18 11:21:03.146618 [ 35675 ] {f0cd5cf5-951e-4744-96ff-906aea07d2e7} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.149241 [ 35659 ] {fffce181-d214-4cc5-b0d1-2fa6d42ac827} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectLanguageMixed(NULL, NULL);) 2025.06.18 11:21:03.153300 [ 35659 ] {fffce181-d214-4cc5-b0d1-2fa6d42ac827} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:03.171667 [ 35675 ] {81312707-7ee6-4cec-83ad-b408adaed42e} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactHigh();) 2025.06.18 11:21:03.175215 [ 35675 ] {81312707-7ee6-4cec-83ad-b408adaed42e} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:03.185272 [ 35659 ] {ffdf0d53-3a2d-49fa-aa12-c171a19c0b0c} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectLanguageUnknown(NULL, NULL);) 2025.06.18 11:21:03.189438 [ 35659 ] {ffdf0d53-3a2d-49fa-aa12-c171a19c0b0c} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:03.200685 [ 35675 ] {b1f02df6-8ca9-4148-b5a7-0d6a6e24933b} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactInclusive();) 2025.06.18 11:21:03.204832 [ 35675 ] {b1f02df6-8ca9-4148-b5a7-0d6a6e24933b} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:03.221753 [ 35659 ] {e4e38f7f-9f40-43df-ad34-a9a0722b1b40} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectProgrammingLanguage(NULL, NULL);) 2025.06.18 11:21:03.225907 [ 35659 ] {e4e38f7f-9f40-43df-ad34-a9a0722b1b40} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:03.229522 [ 35675 ] {038e8a8b-035c-4158-9d54-7ed3dd7b17e4} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactLow();) 2025.06.18 11:21:03.233981 [ 35675 ] {038e8a8b-035c-4158-9d54-7ed3dd7b17e4} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.258194 [ 35659 ] {89cc9810-0705-4759-a015-1b61893fd0c2} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectTonality(NULL, NULL);) 2025.06.18 11:21:03.258414 [ 35675 ] {d2f36a95-e3ea-4878-943b-5406278c62f6} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactWeighted();) 2025.06.18 11:21:03.261965 [ 35675 ] {d2f36a95-e3ea-4878-943b-5406278c62f6} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.262102 [ 35659 ] {89cc9810-0705-4759-a015-1b61893fd0c2} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:03.287784 [ 35675 ] {b686bbbc-43ea-46c8-be3f-39e92418d440} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesGK();) 2025.06.18 11:21:03.291208 [ 35659 ] {f8fef636-84a1-4c04-acf2-b6c9f90d4bb1} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGet(NULL, NULL);) 2025.06.18 11:21:03.291353 [ 35675 ] {b686bbbc-43ea-46c8-be3f-39e92418d440} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.294564 [ 35659 ] {f8fef636-84a1-4c04-acf2-b6c9f90d4bb1} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.316784 [ 35675 ] {eb26bc4e-7f5e-4107-9b87-ff0ed78d7b92} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesInterpolatedWeighted();) 2025.06.18 11:21:03.321111 [ 35675 ] {eb26bc4e-7f5e-4107-9b87-ff0ed78d7b92} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.325562 [ 35659 ] {ecff054d-d4b8-4c6d-85ac-e24676031543} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetAll(NULL, NULL);) 2025.06.18 11:21:03.329314 [ 35659 ] {ecff054d-d4b8-4c6d-85ac-e24676031543} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.346481 [ 35675 ] {b5ad7384-e455-41ec-993a-598f0094b8fa} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTDigest();) 2025.06.18 11:21:03.350052 [ 35675 ] {b5ad7384-e455-41ec-993a-598f0094b8fa} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.360499 [ 35659 ] {16f639bc-1035-416e-b71a-1dcea1327e0b} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetChildren(NULL, NULL);) 2025.06.18 11:21:03.364034 [ 35659 ] {16f639bc-1035-416e-b71a-1dcea1327e0b} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.18 11:21:03.374308 [ 35675 ] {1096f65f-6937-4615-a37c-fa62a4da7f23} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTDigestWeighted();) 2025.06.18 11:21:03.377885 [ 35675 ] {1096f65f-6937-4615-a37c-fa62a4da7f23} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.381762 [ 35047 ] {fc6cbaf2-9a84-45b6-9611-30dd8eecbe11} executeQuery: Code: 10. DB::Exception: Not found column id in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT t1.key FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000003325c54e 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fe00 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:03.384235 [ 35047 ] {fc6cbaf2-9a84-45b6-9611-30dd8eecbe11} TCPHandler: Code: 10. DB::Exception: Not found column id in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000003325c54e 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fe00 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:03.395879 [ 35659 ] {5fe591cd-a38a-4190-8d7d-ed604fd1f842} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDate(NULL, NULL);) 2025.06.18 11:21:03.400065 [ 35659 ] {5fe591cd-a38a-4190-8d7d-ed604fd1f842} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.401878 [ 35675 ] {3e3cc06f-4cab-4d1d-be31-6ca6d59d1d9d} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTiming();) 2025.06.18 11:21:03.405599 [ 35675 ] {3e3cc06f-4cab-4d1d-be31-6ca6d59d1d9d} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:03.430441 [ 35659 ] {fa46a274-5832-48bf-9185-f363c34f1009} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDateOrDefault(NULL, NULL);) 2025.06.18 11:21:03.430441 [ 35675 ] {f7e80018-bc9c-4f30-ab24-5aa1a70825d9} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTimingWeighted();) 2025.06.18 11:21:03.434026 [ 35659 ] {fa46a274-5832-48bf-9185-f363c34f1009} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.434026 [ 35675 ] {f7e80018-bc9c-4f30-ab24-5aa1a70825d9} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.464946 [ 35659 ] {face0ddd-2f01-42f5-8004-4230926644ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDateTime(NULL, NULL);) 2025.06.18 11:21:03.469154 [ 35659 ] {face0ddd-2f01-42f5-8004-4230926644ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.501799 [ 35659 ] {1d11a9e8-7f43-4f27-a3a0-549ea5bbc164} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDateTimeOrDefault(NULL, NULL);) 2025.06.18 11:21:03.505705 [ 35659 ] {1d11a9e8-7f43-4f27-a3a0-549ea5bbc164} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.506792 [ 35675 ] {05624943-4f78-44bf-a445-76782e8c435b} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 0, should be 1: In scope SELECT queryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT queryString();) 2025.06.18 11:21:03.510091 [ 35675 ] {05624943-4f78-44bf-a445-76782e8c435b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 0, should be 1: In scope SELECT queryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.533651 [ 35659 ] {0570735a-bf4d-48de-8fc1-5fcf8ca5a5e3} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDescendants(NULL, NULL);) 2025.06.18 11:21:03.533651 [ 35675 ] {bac6b4f7-3a89-4397-a01e-6c196d5805e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT queryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT queryStringAndFragment();) 2025.06.18 11:21:03.537390 [ 35659 ] {0570735a-bf4d-48de-8fc1-5fcf8ca5a5e3} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.18 11:21:03.537565 [ 35675 ] {bac6b4f7-3a89-4397-a01e-6c196d5805e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT queryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.567944 [ 35659 ] {78083393-8725-45e7-9991-2e6ec18e98ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat32(NULL, NULL);) 2025.06.18 11:21:03.572329 [ 35659 ] {78083393-8725-45e7-9991-2e6ec18e98ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.603823 [ 35659 ] {86f4110e-d985-4e02-a88a-a051497eb4b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat32OrDefault(NULL, NULL);) 2025.06.18 11:21:03.608102 [ 35659 ] {86f4110e-d985-4e02-a88a-a051497eb4b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.612758 [ 35675 ] {264011f4-ad2b-4842-b21f-654587a56430} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 0, should be 1: In scope SELECT radians(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT radians();) 2025.06.18 11:21:03.616353 [ 35675 ] {264011f4-ad2b-4842-b21f-654587a56430} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 0, should be 1: In scope SELECT radians(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.639414 [ 35659 ] {be372c9f-6e48-4acb-98c2-53c1d8c27251} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat64(NULL, NULL);) 2025.06.18 11:21:03.643001 [ 35659 ] {be372c9f-6e48-4acb-98c2-53c1d8c27251} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.677218 [ 35659 ] {d082947d-dd99-4c97-a3ab-b2933c798fd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat64OrDefault(NULL, NULL);) 2025.06.18 11:21:03.681571 [ 35659 ] {d082947d-dd99-4c97-a3ab-b2933c798fd4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.781020 [ 35659 ] {26737f6b-9ae5-4e00-af3a-004029357996} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv4(NULL, NULL);) 2025.06.18 11:21:03.784523 [ 35659 ] {26737f6b-9ae5-4e00-af3a-004029357996} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.801404 [ 35675 ] {d8708600-7bd3-4782-a341-cfd84249cbbe} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randBernoulli();) 2025.06.18 11:21:03.806385 [ 35675 ] {d8708600-7bd3-4782-a341-cfd84249cbbe} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.813862 [ 35659 ] {91cc80b4-2309-45aa-be04-f9aec5181679} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv4OrDefault(NULL, NULL);) 2025.06.18 11:21:03.817327 [ 35659 ] {91cc80b4-2309-45aa-be04-f9aec5181679} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.832547 [ 35675 ] {358c7eb9-9b65-40ef-b00c-a4c6469ffd22} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randBinomial();) 2025.06.18 11:21:03.837084 [ 35675 ] {358c7eb9-9b65-40ef-b00c-a4c6469ffd22} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.847119 [ 35659 ] {1e1e656e-e322-4ead-9614-dbbba7bfa7b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv6(NULL, NULL);) 2025.06.18 11:21:03.850620 [ 35659 ] {1e1e656e-e322-4ead-9614-dbbba7bfa7b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.880003 [ 35659 ] {bda3c52e-3d3f-43c4-ba61-46eec219151a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv6OrDefault(NULL, NULL);) 2025.06.18 11:21:03.883407 [ 35659 ] {bda3c52e-3d3f-43c4-ba61-46eec219151a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.911473 [ 35659 ] {57394712-d837-4d38-8e87-90d13eeca7a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt16(NULL, NULL);) 2025.06.18 11:21:03.914573 [ 35675 ] {d9a07b9e-a306-456b-91bf-ae2191d75726} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randChiSquared();) 2025.06.18 11:21:03.914973 [ 35659 ] {57394712-d837-4d38-8e87-90d13eeca7a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.918722 [ 35675 ] {d9a07b9e-a306-456b-91bf-ae2191d75726} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.944625 [ 35659 ] {a366ea8f-bf1f-41b6-8715-8187f080120f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt16OrDefault(NULL, NULL);) 2025.06.18 11:21:03.948086 [ 35659 ] {a366ea8f-bf1f-41b6-8715-8187f080120f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.977526 [ 35659 ] {8b360a9b-a59c-4c86-9228-91c1585322c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt32(NULL, NULL);) 2025.06.18 11:21:03.981634 [ 35659 ] {8b360a9b-a59c-4c86-9228-91c1585322c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:03.998748 [ 35675 ] {7318efa7-6c6b-4d8b-b3e4-d4c05de4006d} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randExponential();) 2025.06.18 11:21:04.003371 [ 35675 ] {7318efa7-6c6b-4d8b-b3e4-d4c05de4006d} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.011896 [ 35659 ] {c2b51ed2-1ea3-4d1d-8558-037977e8cf08} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt32OrDefault(NULL, NULL);) 2025.06.18 11:21:04.015609 [ 35659 ] {c2b51ed2-1ea3-4d1d-8558-037977e8cf08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.030925 [ 35675 ] {b4e9827a-f24a-485f-984f-0aecde9f74fb} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randFisherF();) 2025.06.18 11:21:04.035070 [ 35675 ] {b4e9827a-f24a-485f-984f-0aecde9f74fb} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.046055 [ 35659 ] {11913569-68c8-4c71-87f4-6e04c057e725} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt64(NULL, NULL);) 2025.06.18 11:21:04.049716 [ 35659 ] {11913569-68c8-4c71-87f4-6e04c057e725} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.058982 [ 35675 ] {85b00007-6c6b-454d-8e5c-3db8b10ce3f3} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randLogNormal();) 2025.06.18 11:21:04.062568 [ 35675 ] {85b00007-6c6b-454d-8e5c-3db8b10ce3f3} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.078990 [ 35659 ] {82345c11-b352-4a49-8c8b-f39f2db9d67a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt64OrDefault(NULL, NULL);) 2025.06.18 11:21:04.082409 [ 35659 ] {82345c11-b352-4a49-8c8b-f39f2db9d67a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.086938 [ 35675 ] {8e955f75-ef19-40ec-ae75-02f43317ee63} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randNegativeBinomial();) 2025.06.18 11:21:04.090393 [ 35675 ] {8e955f75-ef19-40ec-ae75-02f43317ee63} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.112763 [ 35659 ] {155554ac-678f-40bb-89ad-22e1f4d8ce7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt8(NULL, NULL);) 2025.06.18 11:21:04.113704 [ 35675 ] {f6c492a3-b7a0-4614-acc3-e4dbbee7920c} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randNormal();) 2025.06.18 11:21:04.116137 [ 35659 ] {155554ac-678f-40bb-89ad-22e1f4d8ce7b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.117289 [ 35675 ] {f6c492a3-b7a0-4614-acc3-e4dbbee7920c} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.141647 [ 35675 ] {e5453bf5-7175-4373-b1fa-0c8528a9e141} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randPoisson();) 2025.06.18 11:21:04.146447 [ 35659 ] {2bc66b59-974d-41b7-aed2-c46557760c17} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt8OrDefault(NULL, NULL);) 2025.06.18 11:21:04.152868 [ 35675 ] {e5453bf5-7175-4373-b1fa-0c8528a9e141} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.152890 [ 35659 ] {2bc66b59-974d-41b7-aed2-c46557760c17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.176465 [ 35675 ] {bfa90a09-b4ad-40b3-a041-8454c4e9c0be} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randStudentT();) 2025.06.18 11:21:04.180452 [ 35675 ] {bfa90a09-b4ad-40b3-a041-8454c4e9c0be} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.181159 [ 35659 ] {65a86d5c-97f8-47bd-b20c-d55b1568e40f} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetOrDefault(NULL, NULL);) 2025.06.18 11:21:04.184895 [ 35659 ] {65a86d5c-97f8-47bd-b20c-d55b1568e40f} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.208471 [ 35675 ] {bfa8ff6c-cd48-4e30-ad1f-342a434a56ac} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randUniform();) 2025.06.18 11:21:04.212821 [ 35675 ] {bfa8ff6c-cd48-4e30-ad1f-342a434a56ac} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.216418 [ 35659 ] {a6c2773c-5cb2-4eaa-8c5a-0f2d2946102c} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetOrNull(NULL, NULL);) 2025.06.18 11:21:04.219935 [ 35659 ] {a6c2773c-5cb2-4eaa-8c5a-0f2d2946102c} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.240378 [ 35675 ] {a8a0aaa1-12bb-4b8d-8c73-ad4049eb928a} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 0, should be 1: In scope SELECT randomFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomFixedString();) 2025.06.18 11:21:04.244479 [ 35675 ] {a8a0aaa1-12bb-4b8d-8c73-ad4049eb928a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 0, should be 1: In scope SELECT randomFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.249694 [ 35659 ] {3161fe92-9c66-4e31-a73e-a72ea7355b61} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetString(NULL, NULL);) 2025.06.18 11:21:04.253419 [ 35659 ] {3161fe92-9c66-4e31-a73e-a72ea7355b61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.269711 [ 35675 ] {b88120e8-e228-4245-a9ac-80a85d964fcf} executeQuery: Code: 42. DB::Exception: Function randomPrintableASCII requires at least one argument: the size of resulting string: In scope SELECT randomPrintableASCII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomPrintableASCII();) 2025.06.18 11:21:04.273707 [ 35675 ] {b88120e8-e228-4245-a9ac-80a85d964fcf} TCPHandler: Code: 42. DB::Exception: Function randomPrintableASCII requires at least one argument: the size of resulting string: In scope SELECT randomPrintableASCII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.281134 [ 35659 ] {ec8cae8e-6506-489a-ac8f-4567ad3e6188} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetStringOrDefault(NULL, NULL);) 2025.06.18 11:21:04.284634 [ 35659 ] {ec8cae8e-6506-489a-ac8f-4567ad3e6188} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.300351 [ 35675 ] {7b8cb998-aed6-474b-873e-5fa387ca3641} executeQuery: Code: 42. DB::Exception: Function randomString requires at least one argument: the size of resulting string: In scope SELECT randomString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomString();) 2025.06.18 11:21:04.304563 [ 35675 ] {7b8cb998-aed6-474b-873e-5fa387ca3641} TCPHandler: Code: 42. DB::Exception: Function randomString requires at least one argument: the size of resulting string: In scope SELECT randomString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.314949 [ 35659 ] {1750cba1-370b-4bc0-8db5-a4b4296d3f6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt16(NULL, NULL);) 2025.06.18 11:21:04.318558 [ 35659 ] {1750cba1-370b-4bc0-8db5-a4b4296d3f6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.332344 [ 35675 ] {bdb98485-cc1b-4bc0-958c-c32f7acb8ede} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 0, should be 1: In scope SELECT randomStringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomStringUTF8();) 2025.06.18 11:21:04.336749 [ 35675 ] {bdb98485-cc1b-4bc0-958c-c32f7acb8ede} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 0, should be 1: In scope SELECT randomStringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.348910 [ 35659 ] {e8431e93-0880-4fd7-9c31-2839c61ac6b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt16OrDefault(NULL, NULL);) 2025.06.18 11:21:04.352413 [ 35659 ] {e8431e93-0880-4fd7-9c31-2839c61ac6b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.361330 [ 35675 ] {c55adaf9-430f-4322-9b3b-666385ff7b10} executeQuery: Code: 42. DB::Exception: Function range needs 1..3 arguments; passed 0.: In scope SELECT range(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT range();) 2025.06.18 11:21:04.365105 [ 35675 ] {c55adaf9-430f-4322-9b3b-666385ff7b10} TCPHandler: Code: 42. DB::Exception: Function range needs 1..3 arguments; passed 0.: In scope SELECT range(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.382896 [ 35659 ] {9924801a-3c72-46a7-9413-f7efa22eeb45} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt32(NULL, NULL);) 2025.06.18 11:21:04.386750 [ 35659 ] {9924801a-3c72-46a7-9413-f7efa22eeb45} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.411397 [ 35675 ] {d7b042e9-2f4b-47e4-879d-21f271f4fc39} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rank();) 2025.06.18 11:21:04.417102 [ 35675 ] {d7b042e9-2f4b-47e4-879d-21f271f4fc39} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:04.418505 [ 35659 ] {405ca378-ecb8-4ce8-a0ec-e89263292331} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt32OrDefault(NULL, NULL);) 2025.06.18 11:21:04.421915 [ 35659 ] {405ca378-ecb8-4ce8-a0ec-e89263292331} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.439922 [ 35675 ] {c15e4b88-d312-4c22-8061-6368ba5e825c} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rankCorr();) 2025.06.18 11:21:04.443893 [ 35675 ] {c15e4b88-d312-4c22-8061-6368ba5e825c} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.451397 [ 35659 ] {2a5532d9-4a54-414b-bccf-927ef4282d2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt64(NULL, NULL);) 2025.06.18 11:21:04.455241 [ 35659 ] {2a5532d9-4a54-414b-bccf-927ef4282d2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.468165 [ 35675 ] {3bf2efae-d9d2-45ee-a2f2-1b0d070730df} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTLineString();) 2025.06.18 11:21:04.472030 [ 35675 ] {3bf2efae-d9d2-45ee-a2f2-1b0d070730df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.486770 [ 35659 ] {8b0533ab-0bd3-4c8f-af63-f6fa926998f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt64OrDefault(NULL, NULL);) 2025.06.18 11:21:04.490274 [ 35659 ] {8b0533ab-0bd3-4c8f-af63-f6fa926998f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.495801 [ 35675 ] {38dd9ab3-5b4c-4364-9397-5e006d73e7dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTMultiLineString();) 2025.06.18 11:21:04.498417 [ 35675 ] {38dd9ab3-5b4c-4364-9397-5e006d73e7dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.524871 [ 35659 ] {50f81a1f-e2d9-473b-bef1-3d92656226ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt8(NULL, NULL);) 2025.06.18 11:21:04.528760 [ 35675 ] {b7d255a9-faf6-479d-9219-71b507dfa480} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTMultiPolygon();) 2025.06.18 11:21:04.529262 [ 35659 ] {50f81a1f-e2d9-473b-bef1-3d92656226ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.532794 [ 35675 ] {b7d255a9-faf6-479d-9219-71b507dfa480} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.557907 [ 35675 ] {fba807a3-2987-4532-b304-1dba776dbcf6} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 0, should be 1: In scope SELECT readWKTPoint(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTPoint();) 2025.06.18 11:21:04.561429 [ 35675 ] {fba807a3-2987-4532-b304-1dba776dbcf6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 0, should be 1: In scope SELECT readWKTPoint(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.565335 [ 35659 ] {6118a58b-bc94-4421-abaf-1119a0606477} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt8OrDefault(NULL, NULL);) 2025.06.18 11:21:04.569820 [ 35659 ] {6118a58b-bc94-4421-abaf-1119a0606477} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.585083 [ 35675 ] {7f9fe908-71e9-4358-b6e0-989e2037ad9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTPolygon();) 2025.06.18 11:21:04.588648 [ 35675 ] {7f9fe908-71e9-4358-b6e0-989e2037ad9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.604973 [ 35659 ] {3b050df2-7472-4e8a-8c0e-07a8c0c6aa8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUUID(NULL, NULL);) 2025.06.18 11:21:04.609850 [ 35659 ] {3b050df2-7472-4e8a-8c0e-07a8c0c6aa8f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.612661 [ 35675 ] {ddfa2225-bd02-4aa2-b281-13c285c613a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 0, should be 1: In scope SELECT readWKTRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTRing();) 2025.06.18 11:21:04.616433 [ 35675 ] {ddfa2225-bd02-4aa2-b281-13c285c613a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 0, should be 1: In scope SELECT readWKTRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.637620 [ 35675 ] {c0037d6b-7071-468e-9dcb-53b11909d3a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT regexpExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regexpExtract();) 2025.06.18 11:21:04.641066 [ 35675 ] {c0037d6b-7071-468e-9dcb-53b11909d3a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT regexpExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.644981 [ 35659 ] {3679cb4e-db75-46de-b87c-8eea97ea5fb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUUIDOrDefault(NULL, NULL);) 2025.06.18 11:21:04.649344 [ 35659 ] {3679cb4e-db75-46de-b87c-8eea97ea5fb3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.662959 [ 35675 ] {0534d492-d4db-46fc-9cb1-33df8a5846c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 0, should be 1: In scope SELECT regexpQuoteMeta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regexpQuoteMeta();) 2025.06.18 11:21:04.666397 [ 35675 ] {0534d492-d4db-46fc-9cb1-33df8a5846c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 0, should be 1: In scope SELECT regexpQuoteMeta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.697136 [ 35675 ] {be2ad4b1-803b-42c6-a834-8d35f5406dc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionHierarchy();) 2025.06.18 11:21:04.700662 [ 35675 ] {be2ad4b1-803b-42c6-a834-8d35f5406dc4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.721081 [ 35675 ] {d7a3aff8-4237-4222-a37f-8ed9c74e68f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 0, should be 2 or 3.: In scope SELECT regionIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionIn();) 2025.06.18 11:21:04.724457 [ 35675 ] {d7a3aff8-4237-4222-a37f-8ed9c74e68f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 0, should be 2 or 3.: In scope SELECT regionIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.733917 [ 35659 ] {59721cb6-2332-49ef-a10e-2850f0692e0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictIsIn(NULL, NULL);) 2025.06.18 11:21:04.737555 [ 35659 ] {59721cb6-2332-49ef-a10e-2850f0692e0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.746273 [ 35675 ] {f59f49f1-c39f-4eb1-b03a-73e86c33f2ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToArea(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToArea();) 2025.06.18 11:21:04.749685 [ 35675 ] {f59f49f1-c39f-4eb1-b03a-73e86c33f2ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToArea(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.766847 [ 35659 ] {fe733e35-b6ed-4271-906c-d747d21439d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT displayName(NULL, NULL);) 2025.06.18 11:21:04.770370 [ 35659 ] {fe733e35-b6ed-4271-906c-d747d21439d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.774069 [ 35675 ] {d05d1d35-fb6c-4769-840c-607e9ac137ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToCity();) 2025.06.18 11:21:04.777692 [ 35675 ] {d05d1d35-fb6c-4769-840c-607e9ac137ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.800689 [ 35675 ] {ab485b66-3463-46c7-ac14-56666e47ddc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToContinent();) 2025.06.18 11:21:04.804177 [ 35675 ] {ab485b66-3463-46c7-ac14-56666e47ddc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.827376 [ 35675 ] {d452c29e-8fe4-4a64-b97d-5f74227f0d68} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCountry(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToCountry();) 2025.06.18 11:21:04.831206 [ 35675 ] {d452c29e-8fe4-4a64-b97d-5f74227f0d68} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCountry(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.855363 [ 35675 ] {a3cc49ea-9bdc-4976-923d-5b012ca2c278} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToDistrict(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToDistrict();) 2025.06.18 11:21:04.859571 [ 35675 ] {a3cc49ea-9bdc-4976-923d-5b012ca2c278} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToDistrict(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.884426 [ 35675 ] {6914b5c3-4a4f-4043-bae1-aa708d3258c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToName();) 2025.06.18 11:21:04.887935 [ 35675 ] {6914b5c3-4a4f-4043-bae1-aa708d3258c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.910068 [ 35675 ] {e69fc720-75c5-45be-9742-b347faa647c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToPopulation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToPopulation();) 2025.06.18 11:21:04.913725 [ 35675 ] {e69fc720-75c5-45be-9742-b347faa647c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToPopulation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.937718 [ 35675 ] {220f8d2d-4669-494d-a36e-f7145c3398b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToTopContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToTopContinent();) 2025.06.18 11:21:04.941519 [ 35675 ] {220f8d2d-4669-494d-a36e-f7145c3398b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToTopContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:04.978016 [ 35675 ] {65dd34eb-f581-4135-9fb1-6b30898d774e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 0, should be 2: In scope SELECT reinterpret(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpret();) 2025.06.18 11:21:04.981968 [ 35675 ] {65dd34eb-f581-4135-9fb1-6b30898d774e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 0, should be 2: In scope SELECT reinterpret(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.005726 [ 35675 ] {1d4e7032-5611-445a-b258-936e69f61eb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsDate();) 2025.06.18 11:21:05.010735 [ 35675 ] {1d4e7032-5611-445a-b258-936e69f61eb7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.033113 [ 35659 ] {975f3d5d-01c6-48d9-bc7a-d522dbfcd6d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT distanceLp(NULL, NULL);) 2025.06.18 11:21:05.033898 [ 35675 ] {5bf77227-b93b-4647-add0-4f8c8b539293} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsDateTime();) 2025.06.18 11:21:05.038025 [ 35659 ] {975f3d5d-01c6-48d9-bc7a-d522dbfcd6d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.038791 [ 35675 ] {5bf77227-b93b-4647-add0-4f8c8b539293} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.065542 [ 35675 ] {3b80ee7e-a563-4a2e-9a2b-cd7e1998efa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsFixedString();) 2025.06.18 11:21:05.070624 [ 35675 ] {3b80ee7e-a563-4a2e-9a2b-cd7e1998efa9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.096893 [ 35675 ] {ced7dc68-dc82-45eb-94cf-35cf07941517} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsFloat32();) 2025.06.18 11:21:05.100970 [ 35675 ] {ced7dc68-dc82-45eb-94cf-35cf07941517} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.126606 [ 35675 ] {c1b8e51e-fcc4-4e41-824b-ea8f537ef57a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsFloat64();) 2025.06.18 11:21:05.130670 [ 35675 ] {c1b8e51e-fcc4-4e41-824b-ea8f537ef57a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.154549 [ 35675 ] {5629b8d6-cac3-42b0-b361-36db0154c558} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt128();) 2025.06.18 11:21:05.157963 [ 35675 ] {5629b8d6-cac3-42b0-b361-36db0154c558} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.183010 [ 35675 ] {940e658c-cfdc-4029-a305-787685e0f6b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt16();) 2025.06.18 11:21:05.187027 [ 35675 ] {940e658c-cfdc-4029-a305-787685e0f6b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.187088 [ 35659 ] {5219f74e-d5ab-4592-80f1-691b8669c666} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domain(NULL, NULL);) 2025.06.18 11:21:05.190514 [ 35659 ] {5219f74e-d5ab-4592-80f1-691b8669c666} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.212559 [ 35675 ] {5a243631-aff6-40e5-8394-bc917a1dacc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt256();) 2025.06.18 11:21:05.216036 [ 35675 ] {5a243631-aff6-40e5-8394-bc917a1dacc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.219163 [ 35659 ] {99eae9bc-93a7-4c59-a587-555c3d7d1f98} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domainRFC(NULL, NULL);) 2025.06.18 11:21:05.222954 [ 35659 ] {99eae9bc-93a7-4c59-a587-555c3d7d1f98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.241869 [ 35675 ] {40866f56-49dd-44d4-afc7-367c3c461c57} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt32();) 2025.06.18 11:21:05.245944 [ 35675 ] {40866f56-49dd-44d4-afc7-367c3c461c57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.254121 [ 35659 ] {580bbb9d-9a61-4f4b-bd84-579602e81ed9} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domainWithoutWWW(NULL, NULL);) 2025.06.18 11:21:05.257534 [ 35659 ] {580bbb9d-9a61-4f4b-bd84-579602e81ed9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.270823 [ 35675 ] {800ed285-6a9e-4712-9982-b1f282297742} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt64();) 2025.06.18 11:21:05.274924 [ 35675 ] {800ed285-6a9e-4712-9982-b1f282297742} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.287491 [ 35659 ] {e5d0be0b-4f41-46df-b0e4-dbc5825b7716} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domainWithoutWWWRFC(NULL, NULL);) 2025.06.18 11:21:05.290882 [ 35659 ] {e5d0be0b-4f41-46df-b0e4-dbc5825b7716} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.299218 [ 35675 ] {7dc234c9-305d-425a-980a-7a20d30f22eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt8();) 2025.06.18 11:21:05.303202 [ 35675 ] {7dc234c9-305d-425a-980a-7a20d30f22eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.325860 [ 35675 ] {bf9b81ba-ad28-48de-a9bb-f0f3e3c2ccde} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsString();) 2025.06.18 11:21:05.329466 [ 35675 ] {bf9b81ba-ad28-48de-a9bb-f0f3e3c2ccde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.353747 [ 35675 ] {4e48fbed-7540-4936-b878-fb034d731927} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt128();) 2025.06.18 11:21:05.357691 [ 35675 ] {4e48fbed-7540-4936-b878-fb034d731927} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.378684 [ 35659 ] {a46453dd-0dda-48cb-b227-695df6adb954} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dumpColumnStructure(NULL, NULL);) 2025.06.18 11:21:05.382228 [ 35659 ] {a46453dd-0dda-48cb-b227-695df6adb954} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.382423 [ 35675 ] {78b577b3-3981-4d6a-852a-378f31c5ba9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt16();) 2025.06.18 11:21:05.385475 [ 35675 ] {78b577b3-3981-4d6a-852a-378f31c5ba9d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.408460 [ 35675 ] {fc372db6-44c6-4cbf-89cb-b27ad8429ffb} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt256();) 2025.06.18 11:21:05.408460 [ 35659 ] {7f981df6-bbdf-4cd6-96cd-4c0c642f0cb2} executeQuery: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dynamicElement(NULL, NULL);) 2025.06.18 11:21:05.411901 [ 35675 ] {fc372db6-44c6-4cbf-89cb-b27ad8429ffb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.411901 [ 35659 ] {7f981df6-bbdf-4cd6-96cd-4c0c642f0cb2} TCPHandler: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:05.435731 [ 35675 ] {748ba30b-bbc7-4ec7-a190-433d32cb55f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt32();) 2025.06.18 11:21:05.439505 [ 35675 ] {748ba30b-bbc7-4ec7-a190-433d32cb55f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.445719 [ 35659 ] {0ec75392-e42c-4686-a5a0-a6fc111b1c8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dynamicType(NULL, NULL);) 2025.06.18 11:21:05.449732 [ 35659 ] {0ec75392-e42c-4686-a5a0-a6fc111b1c8f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.463057 [ 35675 ] {9496bb47-cd68-400d-8532-45115974b558} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt64();) 2025.06.18 11:21:05.466910 [ 35675 ] {9496bb47-cd68-400d-8532-45115974b558} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.477511 [ 35659 ] {09687110-fe0a-47f8-8bc2-8397295e2cb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT e(NULL, NULL);) 2025.06.18 11:21:05.481696 [ 35659 ] {09687110-fe0a-47f8-8bc2-8397295e2cb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.491135 [ 35675 ] {ed45e5d7-def5-41ee-8368-a07b828f7210} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt8();) 2025.06.18 11:21:05.495141 [ 35675 ] {ed45e5d7-def5-41ee-8368-a07b828f7210} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.528145 [ 35675 ] {bd1610f5-2cb1-4085-b4c5-a2c717f061cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUUID();) 2025.06.18 11:21:05.534058 [ 35675 ] {bd1610f5-2cb1-4085-b4c5-a2c717f061cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.560073 [ 35675 ] {78997451-a1d5-44c1-8b12-b9a99d2cc032} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 0, should be 2: In scope SELECT repeat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT repeat();) 2025.06.18 11:21:05.563559 [ 35675 ] {78997451-a1d5-44c1-8b12-b9a99d2cc032} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 0, should be 2: In scope SELECT repeat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.588561 [ 35675 ] {e896e04d-9b5a-416b-a71d-caed473b7777} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replace();) 2025.06.18 11:21:05.592420 [ 35675 ] {e896e04d-9b5a-416b-a71d-caed473b7777} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.616159 [ 35675 ] {4b42d71e-d37c-4341-b69b-9512a722dd0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replaceAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceAll();) 2025.06.18 11:21:05.619780 [ 35675 ] {4b42d71e-d37c-4341-b69b-9512a722dd0d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replaceAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.634170 [ 35659 ] {0deaddb4-84fa-4e88-855c-777e3aca2992} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT empty(NULL, NULL);) 2025.06.18 11:21:05.637714 [ 35659 ] {0deaddb4-84fa-4e88-855c-777e3aca2992} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.640287 [ 35675 ] {cd3b716e-06c3-4d18-aad4-67f5c38480c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 0, should be 3: In scope SELECT replaceOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceOne();) 2025.06.18 11:21:05.643554 [ 35675 ] {cd3b716e-06c3-4d18-aad4-67f5c38480c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 0, should be 3: In scope SELECT replaceOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.665859 [ 35675 ] {514b6fa8-a3f1-4371-9c4e-66a85a389e58} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceRegexpAll();) 2025.06.18 11:21:05.665859 [ 35659 ] {83abf0d7-1edc-49ab-9311-11f150b42981} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayDate(NULL, NULL);) 2025.06.18 11:21:05.669498 [ 35659 ] {83abf0d7-1edc-49ab-9311-11f150b42981} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.669580 [ 35675 ] {514b6fa8-a3f1-4371-9c4e-66a85a389e58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.695927 [ 35675 ] {5ec7753c-5303-4d5a-af92-178966a9e91f} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceRegexpOne();) 2025.06.18 11:21:05.697763 [ 35659 ] {d11f1aff-1b6f-47da-8509-6f8662a94967} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayDateTime(NULL, NULL);) 2025.06.18 11:21:05.699639 [ 35675 ] {5ec7753c-5303-4d5a-af92-178966a9e91f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.701114 [ 35659 ] {d11f1aff-1b6f-47da-8509-6f8662a94967} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.723377 [ 35675 ] {e5286f69-d4b1-4c31-b227-ee61007e7bfb} executeQuery: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 0: In scope SELECT replicate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replicate();) 2025.06.18 11:21:05.729216 [ 35659 ] {865187bb-a305-4067-b8a4-452b4450bae7} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayFloat32(NULL, NULL);) 2025.06.18 11:21:05.753129 [ 35659 ] {865187bb-a305-4067-b8a4-452b4450bae7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.753579 [ 35675 ] {e5286f69-d4b1-4c31-b227-ee61007e7bfb} TCPHandler: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 0: In scope SELECT replicate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:05.777289 [ 35675 ] {a0de3dda-05ab-48e0-b3fb-45463e16296c} executeQuery: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT retention();) 2025.06.18 11:21:05.781101 [ 35675 ] {a0de3dda-05ab-48e0-b3fb-45463e16296c} TCPHandler: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.781248 [ 35659 ] {cc0a28c0-ffc0-4e4b-bc71-23378a290cd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayFloat64(NULL, NULL);) 2025.06.18 11:21:05.784798 [ 35659 ] {cc0a28c0-ffc0-4e4b-bc71-23378a290cd5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.805363 [ 35675 ] {d1a46086-966e-4cc9-a99a-4ca71e771c01} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 0, should be 1: In scope SELECT reverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reverse();) 2025.06.18 11:21:05.809876 [ 35675 ] {d1a46086-966e-4cc9-a99a-4ca71e771c01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 0, should be 1: In scope SELECT reverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.816368 [ 35659 ] {475209a0-d653-4351-bfb8-1d89220c5c22} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt16(NULL, NULL);) 2025.06.18 11:21:05.820195 [ 35659 ] {475209a0-d653-4351-bfb8-1d89220c5c22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.836231 [ 35675 ] {cf52a51e-f78d-44b0-b74c-2886180a473c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 0, should be 1: In scope SELECT reverseUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reverseUTF8();) 2025.06.18 11:21:05.840266 [ 35675 ] {cf52a51e-f78d-44b0-b74c-2886180a473c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 0, should be 1: In scope SELECT reverseUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.852438 [ 35659 ] {4c9185ff-157b-403a-8d93-a580a2934fe1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt32(NULL, NULL);) 2025.06.18 11:21:05.856844 [ 35659 ] {4c9185ff-157b-403a-8d93-a580a2934fe1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.886920 [ 35659 ] {c2f5e344-3c28-4c0a-9828-3c6f60b3f6ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt64(NULL, NULL);) 2025.06.18 11:21:05.890758 [ 35659 ] {c2f5e344-3c28-4c0a-9828-3c6f60b3f6ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.927105 [ 35675 ] {d382bc7c-6b85-4c09-81f4-9aa91ab24740} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 0, should be 2: In scope SELECT right(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT right();) 2025.06.18 11:21:05.931668 [ 35675 ] {d382bc7c-6b85-4c09-81f4-9aa91ab24740} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 0, should be 2: In scope SELECT right(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.945035 [ 35659 ] {578ad319-60be-48bd-bca4-22b3cb003485} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt8(NULL, NULL);) 2025.06.18 11:21:05.949921 [ 35659 ] {578ad319-60be-48bd-bca4-22b3cb003485} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.956408 [ 35675 ] {8363946f-c645-4666-9cdc-430a08997a38} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rightPad();) 2025.06.18 11:21:05.960958 [ 35675 ] {8363946f-c645-4666-9cdc-430a08997a38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.974863 [ 35659 ] {e372c725-7ced-4a17-85a7-dc2f34f73fe0} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayString(NULL, NULL);) 2025.06.18 11:21:05.978321 [ 35659 ] {e372c725-7ced-4a17-85a7-dc2f34f73fe0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:05.985638 [ 35675 ] {2278771f-7b2f-499b-aa41-c0fbc4e1a923} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rightPadUTF8();) 2025.06.18 11:21:05.989759 [ 35675 ] {2278771f-7b2f-499b-aa41-c0fbc4e1a923} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.006021 [ 35659 ] {2af514d3-267e-4816-886e-7ac5ab9d29d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayToSingle(NULL, NULL);) 2025.06.18 11:21:06.009563 [ 35659 ] {2af514d3-267e-4816-886e-7ac5ab9d29d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.016120 [ 35675 ] {36c47e1e-6532-4d25-b8be-cb7d3a6cd962} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 0, should be 2: In scope SELECT rightUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rightUTF8();) 2025.06.18 11:21:06.020364 [ 35675 ] {36c47e1e-6532-4d25-b8be-cb7d3a6cd962} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 0, should be 2: In scope SELECT rightUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.037226 [ 35659 ] {35a95cfa-7490-40a6-ba4a-f501ffdf70d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt16(NULL, NULL);) 2025.06.18 11:21:06.040738 [ 35659 ] {35a95cfa-7490-40a6-ba4a-f501ffdf70d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.049282 [ 35675 ] {8fa02245-58db-4df3-9ea4-9a84240fc098} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT round(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT round();) 2025.06.18 11:21:06.053422 [ 35675 ] {8fa02245-58db-4df3-9ea4-9a84240fc098} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT round(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.068926 [ 35659 ] {97b71df7-2520-4a4a-a52c-190d07513838} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt32(NULL, NULL);) 2025.06.18 11:21:06.072231 [ 35659 ] {97b71df7-2520-4a4a-a52c-190d07513838} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.078083 [ 35675 ] {45461841-e384-400e-92f0-61f649578426} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 0, should be 1: In scope SELECT roundAge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundAge();) 2025.06.18 11:21:06.081795 [ 35675 ] {45461841-e384-400e-92f0-61f649578426} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 0, should be 1: In scope SELECT roundAge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.098243 [ 35659 ] {24d8fa0d-c02e-410d-a4ff-73f1090cb730} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt64(NULL, NULL);) 2025.06.18 11:21:06.101576 [ 35659 ] {24d8fa0d-c02e-410d-a4ff-73f1090cb730} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.107199 [ 35675 ] {8f18d776-6185-4532-9644-06de56e69da1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT roundBankers(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundBankers();) 2025.06.18 11:21:06.110933 [ 35675 ] {8f18d776-6185-4532-9644-06de56e69da1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT roundBankers(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.129271 [ 35659 ] {79a8d89b-e636-4fda-aea5-87287b989044} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt8(NULL, NULL);) 2025.06.18 11:21:06.132489 [ 35659 ] {79a8d89b-e636-4fda-aea5-87287b989044} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.135959 [ 35675 ] {1a7cd30c-21c9-4298-b140-ff44a7c6a97e} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 0, should be 2: In scope SELECT roundDown(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundDown();) 2025.06.18 11:21:06.139788 [ 35675 ] {1a7cd30c-21c9-4298-b140-ff44a7c6a97e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 0, should be 2: In scope SELECT roundDown(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.161017 [ 35659 ] {c381ca00-98bd-4e92-937e-e9339d9a9abb} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT enabledProfiles(NULL, NULL);) 2025.06.18 11:21:06.164848 [ 35659 ] {c381ca00-98bd-4e92-937e-e9339d9a9abb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.166905 [ 35675 ] {c6e00f90-44fb-4b70-bcc4-63eb01660902} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 0, should be 1: In scope SELECT roundDuration(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundDuration();) 2025.06.18 11:21:06.171381 [ 35675 ] {c6e00f90-44fb-4b70-bcc4-63eb01660902} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 0, should be 1: In scope SELECT roundDuration(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.193379 [ 35659 ] {c55b7629-5bed-4b02-a63a-3fc238d926c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT enabledRoles(NULL, NULL);) 2025.06.18 11:21:06.195672 [ 35675 ] {9eebbe84-b66e-487a-ae85-74d43def24ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 0, should be 1: In scope SELECT roundToExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundToExp2();) 2025.06.18 11:21:06.196769 [ 35659 ] {c55b7629-5bed-4b02-a63a-3fc238d926c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.199308 [ 35675 ] {9eebbe84-b66e-487a-ae85-74d43def24ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 0, should be 1: In scope SELECT roundToExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.224547 [ 35659 ] {9e7d9060-3f21-4716-9ee3-4e78e743dac0} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT encodeURLComponent(NULL, NULL);) 2025.06.18 11:21:06.227906 [ 35659 ] {9e7d9060-3f21-4716-9ee3-4e78e743dac0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.256160 [ 35659 ] {317048e0-4c0e-4650-b13c-8919e0709ab6} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT encodeURLFormComponent(NULL, NULL);) 2025.06.18 11:21:06.259461 [ 35659 ] {317048e0-4c0e-4650-b13c-8919e0709ab6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.290111 [ 35659 ] {1486bdb5-2983-4da2-86d3-53b351974e6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT encodeXMLComponent(NULL, NULL);) 2025.06.18 11:21:06.294917 [ 35659 ] {1486bdb5-2983-4da2-86d3-53b351974e6a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.341953 [ 35047 ] {8aff1df6-086e-4568-a654-bf60e12db05b} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: -- `e + 1` is UInt16 SELECT DISTINCT t1.key, toUInt8(t1.id) as e FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND e + 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:06.344506 [ 35047 ] {8aff1df6-086e-4568-a654-bf60e12db05b} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:06.345487 [ 35675 ] {330c179a-5334-4102-86ee-215868c938be} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT row_number();) 2025.06.18 11:21:06.361195 [ 35675 ] {330c179a-5334-4102-86ee-215868c938be} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:06.383032 [ 35675 ] {6ac034c0-9490-4a9f-bd73-5caea40d9ce0} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rpad();) 2025.06.18 11:21:06.388992 [ 35675 ] {6ac034c0-9490-4a9f-bd73-5caea40d9ce0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.419938 [ 35675 ] {422d2789-80e1-4655-b9b2-1d1ce95604fe} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningAccumulate();) 2025.06.18 11:21:06.428206 [ 35675 ] {422d2789-80e1-4655-b9b2-1d1ce95604fe} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:21:06.465891 [ 35675 ] {f9f21a6c-5a5e-448a-a5be-9e845ee23be9} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 0, should be 2: In scope SELECT runningConcurrency(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningConcurrency();) 2025.06.18 11:21:06.469693 [ 35675 ] {f9f21a6c-5a5e-448a-a5be-9e845ee23be9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 0, should be 2: In scope SELECT runningConcurrency(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.497716 [ 35675 ] {5f0c9a39-aa39-4bda-b6a1-18016713d346} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningDifference();) 2025.06.18 11:21:06.502937 [ 35675 ] {5f0c9a39-aa39-4bda-b6a1-18016713d346} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:21:06.538412 [ 35675 ] {deed4db3-52b6-434f-a402-9d99d4285a14} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningDifferenceStartingWithFirstValue();) 2025.06.18 11:21:06.549512 [ 35675 ] {deed4db3-52b6-434f-a402-9d99d4285a14} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:21:06.571940 [ 35675 ] {0392dbb4-fc7a-4dad-894a-37656cd89cca} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 0, should be 3: In scope SELECT s2CapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2CapContains();) 2025.06.18 11:21:06.577964 [ 35675 ] {0392dbb4-fc7a-4dad-894a-37656cd89cca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 0, should be 3: In scope SELECT s2CapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.601004 [ 35675 ] {b4efc0ad-7d04-4f54-b0e9-68c34c8626f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 0, should be 4: In scope SELECT s2CapUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2CapUnion();) 2025.06.18 11:21:06.604756 [ 35675 ] {b4efc0ad-7d04-4f54-b0e9-68c34c8626f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 0, should be 4: In scope SELECT s2CapUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.628870 [ 35675 ] {1373e167-10c6-4e78-9a68-8888eabbbb5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 0, should be 2: In scope SELECT s2CellsIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2CellsIntersect();) 2025.06.18 11:21:06.634701 [ 35659 ] {9dcb5d5c-0bdf-4fd8-8470-d3a1b9181c42} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT erf(NULL, NULL);) 2025.06.18 11:21:06.634890 [ 35675 ] {1373e167-10c6-4e78-9a68-8888eabbbb5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 0, should be 2: In scope SELECT s2CellsIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.639040 [ 35659 ] {9dcb5d5c-0bdf-4fd8-8470-d3a1b9181c42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.657906 [ 35675 ] {21c5d3d9-c537-42d7-ad0a-979e265b7188} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 0, should be 1: In scope SELECT s2GetNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2GetNeighbors();) 2025.06.18 11:21:06.666058 [ 35659 ] {8f9082f7-55c0-4991-b3c0-b27fb02ec107} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT erfc(NULL, NULL);) 2025.06.18 11:21:06.666332 [ 35675 ] {21c5d3d9-c537-42d7-ad0a-979e265b7188} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 0, should be 1: In scope SELECT s2GetNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.669972 [ 35659 ] {8f9082f7-55c0-4991-b3c0-b27fb02ec107} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.695828 [ 35675 ] {3b7dce38-dadd-4f9b-a8b3-1cb1d89e46b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 0, should be 3: In scope SELECT s2RectAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectAdd();) 2025.06.18 11:21:06.699691 [ 35675 ] {3b7dce38-dadd-4f9b-a8b3-1cb1d89e46b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 0, should be 3: In scope SELECT s2RectAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.703202 [ 35659 ] {38aaf82f-9007-47dc-9ed2-d6802dfb012a} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT errorCodeToName(NULL, NULL);) 2025.06.18 11:21:06.707260 [ 35659 ] {38aaf82f-9007-47dc-9ed2-d6802dfb012a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.723974 [ 35675 ] {72d0238e-72fd-49be-a65a-abad4cf3293d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 0, should be 3: In scope SELECT s2RectContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectContains();) 2025.06.18 11:21:06.728110 [ 35675 ] {72d0238e-72fd-49be-a65a-abad4cf3293d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 0, should be 3: In scope SELECT s2RectContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.750528 [ 35675 ] {0d2ec364-6ebc-43fe-b4a7-242dbda95371} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 0, should be 4: In scope SELECT s2RectIntersection(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectIntersection();) 2025.06.18 11:21:06.754045 [ 35675 ] {0d2ec364-6ebc-43fe-b4a7-242dbda95371} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 0, should be 4: In scope SELECT s2RectIntersection(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.777012 [ 35675 ] {04005284-6dcb-4417-8ca6-50c1a9de4ad5} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 0, should be 4: In scope SELECT s2RectUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectUnion();) 2025.06.18 11:21:06.780395 [ 35675 ] {04005284-6dcb-4417-8ca6-50c1a9de4ad5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 0, should be 4: In scope SELECT s2RectUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.792427 [ 35659 ] {020de956-afe2-4c51-a39d-c8575846cb1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exp(NULL, NULL);) 2025.06.18 11:21:06.796027 [ 35659 ] {020de956-afe2-4c51-a39d-c8575846cb1d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.801168 [ 35675 ] {2fccceb8-9e8d-41b8-93ba-5c874aefd8d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 0, should be 1: In scope SELECT s2ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2ToGeo();) 2025.06.18 11:21:06.804772 [ 35675 ] {2fccceb8-9e8d-41b8-93ba-5c874aefd8d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 0, should be 1: In scope SELECT s2ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.826225 [ 35659 ] {434fbdfe-9d52-4bde-aef2-6094f3b5b161} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exp10(NULL, NULL);) 2025.06.18 11:21:06.829960 [ 35659 ] {434fbdfe-9d52-4bde-aef2-6094f3b5b161} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.830327 [ 35675 ] {ed87c8c7-0550-4906-9348-c8203a290ecc} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT scalarProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT scalarProduct();) 2025.06.18 11:21:06.833678 [ 35675 ] {ed87c8c7-0550-4906-9348-c8203a290ecc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT scalarProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.859469 [ 35675 ] {0c09c6ef-3073-4a3b-8f76-81987fe87711} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sequenceCount();) 2025.06.18 11:21:06.861381 [ 35659 ] {026a719b-36c4-469f-a1cf-63bc42d5e525} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exp2(NULL, NULL);) 2025.06.18 11:21:06.863269 [ 35675 ] {0c09c6ef-3073-4a3b-8f76-81987fe87711} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.865190 [ 35659 ] {026a719b-36c4-469f-a1cf-63bc42d5e525} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.888676 [ 35675 ] {1a465ed9-4618-4600-bb8f-3978596ff7e5} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sequenceMatch();) 2025.06.18 11:21:06.892421 [ 35675 ] {1a465ed9-4618-4600-bb8f-3978596ff7e5} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.917711 [ 35675 ] {53cbe4bd-ea39-4091-b033-eaebb89a6a09} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sequenceNextNode();) 2025.06.18 11:21:06.921949 [ 35675 ] {53cbe4bd-ea39-4091-b033-eaebb89a6a09} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.18 11:21:06.946978 [ 35675 ] {11059c26-e404-4389-86cd-3c29fe582667} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT seriesDecomposeSTL();) 2025.06.18 11:21:06.950717 [ 35675 ] {11059c26-e404-4389-86cd-3c29fe582667} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.974490 [ 35675 ] {06e65700-8637-4213-9494-fda9f8c8dc64} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 0.: In scope SELECT seriesOutliersDetectTukey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT seriesOutliersDetectTukey();) 2025.06.18 11:21:06.974495 [ 35659 ] {7f1ef29e-04c9-45fd-826a-d3ee38daa69d} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL);) 2025.06.18 11:21:06.975983 [ 35047 ] {08709590-9f33-4f37-be81-62a6d9565f03} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:06.978217 [ 35675 ] {06e65700-8637-4213-9494-fda9f8c8dc64} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 0.: In scope SELECT seriesOutliersDetectTukey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.978303 [ 35659 ] {7f1ef29e-04c9-45fd-826a-d3ee38daa69d} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:06.978384 [ 35047 ] {08709590-9f33-4f37-be81-62a6d9565f03} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.005584 [ 35675 ] {7a55b4cf-3922-4a60-b838-ffd5e4d025ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT seriesPeriodDetectFFT();) 2025.06.18 11:21:07.010009 [ 35675 ] {7a55b4cf-3922-4a60-b838-ffd5e4d025ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.010428 [ 35659 ] {d24a33f3-7e1d-4e04-a05c-1f1596c7f810} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL);) 2025.06.18 11:21:07.014179 [ 35659 ] {d24a33f3-7e1d-4e04-a05c-1f1596c7f810} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.045021 [ 35659 ] {a8700336-fc0a-46ca-81c0-bfaa6fc434a5} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL);) 2025.06.18 11:21:07.049944 [ 35659 ] {a8700336-fc0a-46ca-81c0-bfaa6fc434a5} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.076828 [ 35671 ] {5530ed69-c7de-4290-b54a-7a99689fe5d9} executeQuery: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number ASC. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46100) (comment: 02293_grouping_function_group_by.sql) (in query: SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:123: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335897be 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.082953 [ 35671 ] {5530ed69-c7de-4290-b54a-7a99689fe5d9} TCPHandler: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number ASC. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:123: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335897be 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.091853 [ 35659 ] {bd4ea3cf-21ef-487b-b64d-407c0ca6dfff} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL);) 2025.06.18 11:21:07.097701 [ 35659 ] {bd4ea3cf-21ef-487b-b64d-407c0ca6dfff} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.430648 [ 35675 ] {abcc72d3-b06a-4f26-b46d-71c7e0130bf7} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 0, should be 1: In scope SELECT sigmoid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sigmoid();) 2025.06.18 11:21:07.435422 [ 35675 ] {abcc72d3-b06a-4f26-b46d-71c7e0130bf7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 0, should be 1: In scope SELECT sigmoid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.460301 [ 35675 ] {0ee982f8-7256-49d2-b755-01ad8ae395f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 0, should be 1: In scope SELECT sign(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sign();) 2025.06.18 11:21:07.469602 [ 35675 ] {0ee982f8-7256-49d2-b755-01ad8ae395f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 0, should be 1: In scope SELECT sign(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.496988 [ 35675 ] {472a355f-a9f5-4770-9b4f-f7eecd7bcdf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractBool();) 2025.06.18 11:21:07.503834 [ 35675 ] {472a355f-a9f5-4770-9b4f-f7eecd7bcdf3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.533915 [ 35675 ] {1745ebdf-3af1-4cbd-b725-0a54f1a2661f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractFloat();) 2025.06.18 11:21:07.537886 [ 35675 ] {1745ebdf-3af1-4cbd-b725-0a54f1a2661f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.561883 [ 35675 ] {45de0ef6-f480-4014-9da1-d152671f5d4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractInt();) 2025.06.18 11:21:07.565308 [ 35675 ] {45de0ef6-f480-4014-9da1-d152671f5d4f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.586008 [ 35675 ] {be2abd17-3dd7-46a3-a122-13e2f62e3bcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractRaw();) 2025.06.18 11:21:07.589150 [ 35675 ] {be2abd17-3dd7-46a3-a122-13e2f62e3bcc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.601184 [ 35047 ] {2cb2db19-77c9-4ab6-83a4-b1b83eee2633} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.604530 [ 35047 ] {2cb2db19-77c9-4ab6-83a4-b1b83eee2633} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.612093 [ 35675 ] {96db8318-4bf7-455f-92c6-2839c56f4d27} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractString();) 2025.06.18 11:21:07.615830 [ 35675 ] {96db8318-4bf7-455f-92c6-2839c56f4d27} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.620112 [ 35659 ] {3fa105ca-d37c-4822-8077-9ffb68cfd6b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT extractTextFromHTML(NULL, NULL);) 2025.06.18 11:21:07.623947 [ 35659 ] {3fa105ca-d37c-4822-8077-9ffb68cfd6b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.640021 [ 35675 ] {4d431d17-6f07-4c39-aad8-6251c63f211b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractUInt();) 2025.06.18 11:21:07.645033 [ 35675 ] {4d431d17-6f07-4c39-aad8-6251c63f211b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.680981 [ 35675 ] {5ac013ac-9029-4a42-a34b-7dfa86fcee3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT simpleJSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONHas();) 2025.06.18 11:21:07.686253 [ 35675 ] {5ac013ac-9029-4a42-a34b-7dfa86fcee3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT simpleJSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.696324 [ 35047 ] {e161c122-fb66-4cb8-96ec-4d7f7714cc49} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id + 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.699144 [ 35047 ] {e161c122-fb66-4cb8-96ec-4d7f7714cc49} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.718432 [ 35675 ] {b50499fd-2311-48e9-b0dd-e2035b9ce2c1} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleLinearRegression();) 2025.06.18 11:21:07.719127 [ 35659 ] {cf116c63-187f-4d7e-8902-742272944442} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT extractURLParameterNames(NULL, NULL);) 2025.06.18 11:21:07.723534 [ 35675 ] {b50499fd-2311-48e9-b0dd-e2035b9ce2c1} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.724776 [ 35659 ] {cf116c63-187f-4d7e-8902-742272944442} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.749797 [ 35675 ] {3c841139-8bb1-4de0-b81f-706191fc72a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 0, should be 1: In scope SELECT sin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sin();) 2025.06.18 11:21:07.752941 [ 35659 ] {3979d60e-b156-4dd2-95b8-1fc9ef67bdb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT extractURLParameters(NULL, NULL);) 2025.06.18 11:21:07.753501 [ 35675 ] {3c841139-8bb1-4de0-b81f-706191fc72a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 0, should be 1: In scope SELECT sin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.758921 [ 35659 ] {3979d60e-b156-4dd2-95b8-1fc9ef67bdb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.759021 [ 35047 ] {578f52a5-7d3e-460a-92cd-479395c0f790} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id + 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.761252 [ 35047 ] {578f52a5-7d3e-460a-92cd-479395c0f790} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:07.781260 [ 35675 ] {3ddfaf64-33bb-492b-b4fc-9cec6d7d1609} executeQuery: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT singleValueOrNull();) 2025.06.18 11:21:07.785792 [ 35675 ] {3ddfaf64-33bb-492b-b4fc-9cec6d7d1609} TCPHandler: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.787410 [ 35659 ] {1e2aadd5-103d-4ff0-96f1-2f327df76774} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT factorial(NULL, NULL);) 2025.06.18 11:21:07.790851 [ 35659 ] {1e2aadd5-103d-4ff0-96f1-2f327df76774} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.811365 [ 35675 ] {a4942718-d582-40ca-8290-f8b4121ed93d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 0, should be 1: In scope SELECT sinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sinh();) 2025.06.18 11:21:07.815869 [ 35675 ] {a4942718-d582-40ca-8290-f8b4121ed93d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 0, should be 1: In scope SELECT sinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:07.966294 [ 35659 ] {4a7afd46-da37-45f4-949a-4f2fe6e3f0a6} executeQuery: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT file(NULL, NULL);) 2025.06.18 11:21:07.974401 [ 35659 ] {4a7afd46-da37-45f4-949a-4f2fe6e3f0a6} TCPHandler: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) 2025.06.18 11:21:08.224493 [ 35659 ] {070b5817-c533-46af-8c58-7b3bbd07b08d} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT finalizeAggregation(NULL, NULL);) 2025.06.18 11:21:08.228258 [ 35659 ] {070b5817-c533-46af-8c58-7b3bbd07b08d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.256582 [ 35659 ] {db1aa624-57b8-4b9c-951d-e8b5ed377eaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT firstLine(NULL, NULL);) 2025.06.18 11:21:08.261506 [ 35659 ] {db1aa624-57b8-4b9c-951d-e8b5ed377eaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.286834 [ 35659 ] {4b70c917-e5fe-4ef3-b9ce-976226b051e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT firstSignificantSubdomain(NULL, NULL);) 2025.06.18 11:21:08.287898 [ 35675 ] {abe1a1ca-7ce6-4984-b566-09811ac66ef0} executeQuery: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT skewPop();) 2025.06.18 11:21:08.290463 [ 35659 ] {4b70c917-e5fe-4ef3-b9ce-976226b051e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.291725 [ 35675 ] {abe1a1ca-7ce6-4984-b566-09811ac66ef0} TCPHandler: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.321717 [ 35675 ] {b2dbff89-3035-474a-9afe-cbf217d0eb19} executeQuery: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT skewSamp();) 2025.06.18 11:21:08.328261 [ 35675 ] {b2dbff89-3035-474a-9afe-cbf217d0eb19} TCPHandler: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.358938 [ 35675 ] {92f324bb-4b76-4e1c-bb30-8c1db7cacaa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 0, should be 1: In scope SELECT sleep(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sleep();) 2025.06.18 11:21:08.364111 [ 35675 ] {92f324bb-4b76-4e1c-bb30-8c1db7cacaa9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 0, should be 1: In scope SELECT sleep(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.391670 [ 35675 ] {f17e453d-a54a-4612-9c34-deee45ec9785} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 0, should be 1: In scope SELECT sleepEachRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sleepEachRow();) 2025.06.18 11:21:08.398240 [ 35675 ] {f17e453d-a54a-4612-9c34-deee45ec9785} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 0, should be 1: In scope SELECT sleepEachRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.429018 [ 35675 ] {975351fe-970e-4144-a71d-ca95be2243cc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeIDToDateTime();) 2025.06.18 11:21:08.434603 [ 35675 ] {975351fe-970e-4144-a71d-ca95be2243cc} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.453958 [ 35659 ] {8a2107c8-affc-4dfd-9e7f-9ea80fa15574} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL);) 2025.06.18 11:21:08.458162 [ 35659 ] {8a2107c8-affc-4dfd-9e7f-9ea80fa15574} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.463062 [ 35675 ] {f214166c-23d1-4296-9c13-d2f666d47a09} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeIDToDateTime64();) 2025.06.18 11:21:08.469563 [ 35675 ] {f214166c-23d1-4296-9c13-d2f666d47a09} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.495234 [ 35675 ] {74c1e0ed-97cd-4d52-923d-727ccfdd5c2c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeToDateTime();) 2025.06.18 11:21:08.499018 [ 35675 ] {74c1e0ed-97cd-4d52-923d-727ccfdd5c2c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.533159 [ 35675 ] {9db198d1-6d8e-4cc3-9079-bb5b8e07b5c6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeToDateTime64();) 2025.06.18 11:21:08.536775 [ 35675 ] {9db198d1-6d8e-4cc3-9079-bb5b8e07b5c6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.559448 [ 35675 ] {f3309471-5da0-40be-92d0-f007ec5e6d32} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 0, should be 1: In scope SELECT soundex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT soundex();) 2025.06.18 11:21:08.562823 [ 35675 ] {f3309471-5da0-40be-92d0-f007ec5e6d32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 0, should be 1: In scope SELECT soundex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.562927 [ 35659 ] {645f4c15-fbc8-4cd1-a449-e13e0d268601} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT first_value_respect_nulls(NULL, NULL);) 2025.06.18 11:21:08.566935 [ 35659 ] {645f4c15-fbc8-4cd1-a449-e13e0d268601} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.587941 [ 35675 ] {145cf85c-99a2-423a-b3b5-46c12363b778} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 0, should be 1: In scope SELECT space(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT space();) 2025.06.18 11:21:08.594516 [ 35675 ] {145cf85c-99a2-423a-b3b5-46c12363b778} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 0, should be 1: In scope SELECT space(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.596063 [ 35659 ] {ec5cc935-a3d7-4db9-815f-505bca6ee576} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT flameGraph(NULL, NULL);) 2025.06.18 11:21:08.605725 [ 35659 ] {ec5cc935-a3d7-4db9-815f-505bca6ee576} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:08.625934 [ 35675 ] {8aa9ce2a-9658-4002-a2c2-47853bd5b31e} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sparkBar();) 2025.06.18 11:21:08.629189 [ 35047 ] {46a8be53-34ad-4727-b63c-bf4a27606b1f} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:08.631940 [ 35047 ] {46a8be53-34ad-4727-b63c-bf4a27606b1f} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:08.635896 [ 35675 ] {8aa9ce2a-9658-4002-a2c2-47853bd5b31e} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.636826 [ 35659 ] {32a16563-8993-4cca-ade0-15ea588e7bb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT flatten(NULL, NULL);) 2025.06.18 11:21:08.644250 [ 35659 ] {32a16563-8993-4cca-ade0-15ea588e7bb1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.665882 [ 35675 ] {f3b7e6b2-4b3a-47ec-8662-7a7a11eed17c} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sparkbar();) 2025.06.18 11:21:08.670269 [ 35675 ] {f3b7e6b2-4b3a-47ec-8662-7a7a11eed17c} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.679570 [ 35659 ] {82f31c44-ee84-4465-90e3-a55325b8d567} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT flattenTuple(NULL, NULL);) 2025.06.18 11:21:08.681764 [ 35047 ] {4a0b36c0-b555-4b7f-8d31-da0fa7e47c86} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:08.684251 [ 35047 ] {4a0b36c0-b555-4b7f-8d31-da0fa7e47c86} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:08.686506 [ 35659 ] {82f31c44-ee84-4465-90e3-a55325b8d567} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.697067 [ 35675 ] {7eb5d2ba-d4fa-4ee2-bf00-2c7b027fe46c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByAlpha();) 2025.06.18 11:21:08.701184 [ 35675 ] {7eb5d2ba-d4fa-4ee2-bf00-2c7b027fe46c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.728720 [ 35675 ] {8caa39a6-f282-449e-ad6d-32624c771dfd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByChar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByChar();) 2025.06.18 11:21:08.732817 [ 35675 ] {8caa39a6-f282-449e-ad6d-32624c771dfd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByChar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.761403 [ 35675 ] {ca2c5e56-5927-4ddf-8a9e-80d8b7d7c4e7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByNonAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByNonAlpha();) 2025.06.18 11:21:08.767877 [ 35675 ] {ca2c5e56-5927-4ddf-8a9e-80d8b7d7c4e7} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByNonAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.810600 [ 35675 ] {b08c373c-dcea-4461-bd5e-11e0af384c76} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByRegexp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByRegexp();) 2025.06.18 11:21:08.814910 [ 35675 ] {b08c373c-dcea-4461-bd5e-11e0af384c76} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByRegexp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.841870 [ 35675 ] {14695d26-c9f0-4104-9898-6ce6122d88c0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByString();) 2025.06.18 11:21:08.847307 [ 35675 ] {14695d26-c9f0-4104-9898-6ce6122d88c0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.881150 [ 35675 ] {43e3e67e-31be-400e-822a-4bd916b7b12d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByWhitespace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByWhitespace();) 2025.06.18 11:21:08.888683 [ 35675 ] {43e3e67e-31be-400e-822a-4bd916b7b12d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByWhitespace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.954444 [ 35659 ] {44dec05a-a23b-41c7-8de1-ea3de671ecb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQuery(NULL, NULL);) 2025.06.18 11:21:08.957988 [ 35659 ] {44dec05a-a23b-41c7-8de1-ea3de671ecb8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.954438 [ 35675 ] {01d14bab-f052-44ff-a1d9-5b3898a0d733} executeQuery: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqid();) 2025.06.18 11:21:08.963643 [ 35675 ] {01d14bab-f052-44ff-a1d9-5b3898a0d733} TCPHandler: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:08.988052 [ 35659 ] {482893bb-633b-492d-b1b3-a56a6e196fca} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQueryOrNull(NULL, NULL);) 2025.06.18 11:21:08.991649 [ 35659 ] {482893bb-633b-492d-b1b3-a56a6e196fca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.019592 [ 35659 ] {0b94bb93-a846-4ef3-9f7b-7c5761e241b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQuerySingleLine(NULL, NULL);) 2025.06.18 11:21:09.028261 [ 35659 ] {0b94bb93-a846-4ef3-9f7b-7c5761e241b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.059786 [ 35659 ] {e7a1fafb-7504-4fc4-b534-8057a75cb005} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL);) 2025.06.18 11:21:09.063703 [ 35659 ] {e7a1fafb-7504-4fc4-b534-8057a75cb005} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.064967 [ 35675 ] {d2433fcc-f4d4-4350-8593-5c6d5f77c08f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 0, should be 1: In scope SELECT sqidDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqidDecode();) 2025.06.18 11:21:09.071856 [ 35675 ] {d2433fcc-f4d4-4350-8593-5c6d5f77c08f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 0, should be 1: In scope SELECT sqidDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.095160 [ 35659 ] {023ee6f2-53df-4b3f-a09b-e6400d5df479} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatReadableDecimalSize(NULL, NULL);) 2025.06.18 11:21:09.097053 [ 35675 ] {8b28055c-a25f-421f-9dc2-94bc908ec35d} executeQuery: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqidEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqidEncode();) 2025.06.18 11:21:09.099479 [ 35659 ] {023ee6f2-53df-4b3f-a09b-e6400d5df479} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.101463 [ 35675 ] {8b28055c-a25f-421f-9dc2-94bc908ec35d} TCPHandler: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqidEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.124517 [ 35675 ] {5f3e038f-1c3d-4e3d-9137-40ff9a9e3b00} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 0, should be 1: In scope SELECT sqrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqrt();) 2025.06.18 11:21:09.126736 [ 35659 ] {7b05bc88-a39f-40fd-8356-fa44c4627875} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatReadableQuantity(NULL, NULL);) 2025.06.18 11:21:09.128356 [ 35675 ] {5f3e038f-1c3d-4e3d-9137-40ff9a9e3b00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 0, should be 1: In scope SELECT sqrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.130423 [ 35659 ] {7b05bc88-a39f-40fd-8356-fa44c4627875} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.168323 [ 35675 ] {af719cf0-f9a4-469d-99fc-5aa3ed80f320} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 0, should be 2: In scope SELECT startsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT startsWith();) 2025.06.18 11:21:09.174466 [ 35675 ] {af719cf0-f9a4-469d-99fc-5aa3ed80f320} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 0, should be 2: In scope SELECT startsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.178103 [ 35659 ] {05005959-6777-410c-8a39-e4d205b552d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatReadableSize(NULL, NULL);) 2025.06.18 11:21:09.182929 [ 35659 ] {05005959-6777-410c-8a39-e4d205b552d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.202945 [ 35675 ] {c68ac35d-4223-494a-91c6-5ca012626d88} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT startsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT startsWithUTF8();) 2025.06.18 11:21:09.209772 [ 35675 ] {c68ac35d-4223-494a-91c6-5ca012626d88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT startsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.229148 [ 35047 ] {d052078e-e885-41e2-a28e-d91d5607f399} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t2.key = t2.key2) AND ((t1.id = t2.id) OR (t2.key2 IS NULL)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 JOIN t2_nullable as t2 ON t2.key == t2.key2 AND (t1.id == t2.id OR isNull(t2.key2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:09.231910 [ 35047 ] {d052078e-e885-41e2-a28e-d91d5607f399} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t2.key = t2.key2) AND ((t1.id = t2.id) OR (t2.key2 IS NULL)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:09.234783 [ 35675 ] {6cf74e95-17d4-4e4c-b86e-bf0419c763de} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevPop();) 2025.06.18 11:21:09.246391 [ 35675 ] {6cf74e95-17d4-4e4c-b86e-bf0419c763de} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.268136 [ 35659 ] {485dfd63-a6b3-4c08-a490-4c332db584a5} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatRow(NULL, NULL);) 2025.06.18 11:21:09.271034 [ 35675 ] {7f4d7a63-64ee-423c-b99b-bc0e1a8a46ce} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevPopStable();) 2025.06.18 11:21:09.271726 [ 35659 ] {485dfd63-a6b3-4c08-a490-4c332db584a5} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:09.276794 [ 35675 ] {7f4d7a63-64ee-423c-b99b-bc0e1a8a46ce} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.293946 [ 35047 ] {4300ec52-746b-4e6a-bfc5-5c468725e03a} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON (t2.key = t2.key2) OR (t1.id = t2.id). (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 JOIN t2 ON t2.key == t2.key2 OR t1.id == t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:09.297889 [ 35675 ] {55c73fee-53ce-4722-aa25-d4384f15ed03} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevSamp();) 2025.06.18 11:21:09.300955 [ 35047 ] {4300ec52-746b-4e6a-bfc5-5c468725e03a} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON (t2.key = t2.key2) OR (t1.id = t2.id). (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:09.301674 [ 35675 ] {55c73fee-53ce-4722-aa25-d4384f15ed03} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.307287 [ 35659 ] {12d32086-74a6-4a70-8a6a-0ec7d0415361} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatRowNoNewline(NULL, NULL);) 2025.06.18 11:21:09.312599 [ 35659 ] {12d32086-74a6-4a70-8a6a-0ec7d0415361} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:09.331203 [ 35675 ] {154b2f1f-dab3-44d3-9184-6f11a422a9a7} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevSampStable();) 2025.06.18 11:21:09.334989 [ 35675 ] {154b2f1f-dab3-44d3-9184-6f11a422a9a7} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.338736 [ 35659 ] {251613e9-ad1c-4ba5-b00f-4ed75187eb95} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fragment(NULL, NULL);) 2025.06.18 11:21:09.342389 [ 35659 ] {251613e9-ad1c-4ba5-b00f-4ed75187eb95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.368546 [ 35659 ] {90b7701e-5542-4331-9b0d-7ac50268baf9} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromDaysSinceYearZero(NULL, NULL);) 2025.06.18 11:21:09.368546 [ 35675 ] {ae86072a-17a9-41c7-baf6-889bd7bb16bb} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stem();) 2025.06.18 11:21:09.372821 [ 35675 ] {ae86072a-17a9-41c7-baf6-889bd7bb16bb} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:09.373503 [ 35659 ] {90b7701e-5542-4331-9b0d-7ac50268baf9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.401151 [ 35659 ] {0688a23b-1e63-4b5b-91a3-573f6e00a54f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL);) 2025.06.18 11:21:09.402372 [ 35675 ] {d26ee685-cddb-4ead-9299-b2619d33d1f1} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stochasticLinearRegression();) 2025.06.18 11:21:09.404708 [ 35659 ] {0688a23b-1e63-4b5b-91a3-573f6e00a54f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.404771 [ 35675 ] {d26ee685-cddb-4ead-9299-b2619d33d1f1} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:09.432867 [ 35659 ] {7f142a30-eaf3-4714-b84f-e86e57fa8d83} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromModifiedJulianDay(NULL, NULL);) 2025.06.18 11:21:09.433927 [ 35675 ] {7168beaa-d5d2-49b6-81ab-06cb62f7f1ca} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stochasticLogisticRegression();) 2025.06.18 11:21:09.437549 [ 35659 ] {7f142a30-eaf3-4714-b84f-e86e57fa8d83} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.439173 [ 35675 ] {7168beaa-d5d2-49b6-81ab-06cb62f7f1ca} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:09.463450 [ 35675 ] {c1c18c47-6cdf-413f-9d36-3e690d467d95} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT str_to_date(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT str_to_date();) 2025.06.18 11:21:09.466533 [ 35659 ] {59bec9f8-5034-4a60-8bfa-a9696baa4b3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL);) 2025.06.18 11:21:09.467026 [ 35675 ] {c1c18c47-6cdf-413f-9d36-3e690d467d95} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT str_to_date(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.470968 [ 35659 ] {59bec9f8-5034-4a60-8bfa-a9696baa4b3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.497507 [ 35675 ] {7e9985e4-cf03-483e-a466-de7499a0bd4e} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT str_to_map(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT str_to_map();) 2025.06.18 11:21:09.500899 [ 35675 ] {7e9985e4-cf03-483e-a466-de7499a0bd4e} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT str_to_map(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.534835 [ 35675 ] {15312ef2-cbb6-40c5-82e8-3184d0b99ed5} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stringJaccardIndex();) 2025.06.18 11:21:09.538698 [ 35675 ] {15312ef2-cbb6-40c5-82e8-3184d0b99ed5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.561594 [ 35675 ] {8da83152-9a92-43ca-8cd2-2e2b4ebab316} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stringJaccardIndexUTF8();) 2025.06.18 11:21:09.566848 [ 35675 ] {8da83152-9a92-43ca-8cd2-2e2b4ebab316} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.591588 [ 35675 ] {32bff5ca-9edc-491a-bb38-ea7764c53eea} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 0, should be 1: In scope SELECT stringToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stringToH3();) 2025.06.18 11:21:09.595147 [ 35675 ] {32bff5ca-9edc-491a-bb38-ea7764c53eea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 0, should be 1: In scope SELECT stringToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.621472 [ 35675 ] {733692de-0c01-46e8-a759-90def5cc87a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT structureToCapnProtoSchema();) 2025.06.18 11:21:09.626791 [ 35675 ] {733692de-0c01-46e8-a759-90def5cc87a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.666442 [ 35675 ] {cfb4c2a1-0a41-4c24-aee3-1b8c272cb856} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToProtobufSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT structureToProtobufSchema();) 2025.06.18 11:21:09.671881 [ 35675 ] {cfb4c2a1-0a41-4c24-aee3-1b8c272cb856} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToProtobufSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.701318 [ 35675 ] {dc7789e4-1c12-4ba3-8598-ff011117c3df} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT studentTTest();) 2025.06.18 11:21:09.706297 [ 35675 ] {dc7789e4-1c12-4ba3-8598-ff011117c3df} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.738052 [ 35675 ] {f3427e2e-dee8-4791-a678-e077ae8ef01c} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 0, should be 3: In scope SELECT subBitmap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subBitmap();) 2025.06.18 11:21:09.741956 [ 35675 ] {f3427e2e-dee8-4791-a678-e077ae8ef01c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 0, should be 3: In scope SELECT subBitmap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.765317 [ 35675 ] {db8bab20-8a41-41a1-bff4-f5a0ccd26814} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 0, should be 2: In scope SELECT subDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subDate();) 2025.06.18 11:21:09.772954 [ 35675 ] {db8bab20-8a41-41a1-bff4-f5a0ccd26814} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 0, should be 2: In scope SELECT subDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.798675 [ 35675 ] {cf3535e2-599c-4b38-aaa5-23203e38eb79} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT substr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substr();) 2025.06.18 11:21:09.802897 [ 35675 ] {cf3535e2-599c-4b38-aaa5-23203e38eb79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT substr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.831468 [ 35675 ] {3afc0714-58d4-41a7-909d-e4b9a20afe3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT substringIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substringIndex();) 2025.06.18 11:21:09.839907 [ 35675 ] {3afc0714-58d4-41a7-909d-e4b9a20afe3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT substringIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.869488 [ 35675 ] {4b21136a-c884-4515-a65f-c83c029bd644} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 0, should be 3: In scope SELECT substringIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substringIndexUTF8();) 2025.06.18 11:21:09.874439 [ 35675 ] {4b21136a-c884-4515-a65f-c83c029bd644} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 0, should be 3: In scope SELECT substringIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.902926 [ 35047 ] {760b9a99-2b6c-43f2-a4d7-47bf0ea554e2} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t2.key = t2.key2) AND (((t1.key = t1.key2) AND (t1.key != 'XXX')) OR (t1.id = t2.id))) AND (t1.id = t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 JOIN t2 ON (t2.key == t2.key2 AND (t1.key == t1.key2 AND t1.key != 'XXX' OR t1.id == t2.id)) AND t1.id == t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:09.906289 [ 35047 ] {760b9a99-2b6c-43f2-a4d7-47bf0ea554e2} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t2.key = t2.key2) AND (((t1.key = t1.key2) AND (t1.key != 'XXX')) OR (t1.id = t2.id))) AND (t1.id = t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:09.907623 [ 35675 ] {973c2d33-7f57-47ae-9a40-66ff7d00258d} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT substringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substringUTF8();) 2025.06.18 11:21:09.911679 [ 35675 ] {973c2d33-7f57-47ae-9a40-66ff7d00258d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT substringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.921649 [ 35659 ] {82acbcc4-c528-445e-8a05-916db0219cde} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fullHostName(NULL, NULL);) 2025.06.18 11:21:09.932951 [ 35659 ] {82acbcc4-c528-445e-8a05-916db0219cde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.950139 [ 35675 ] {aaa1fb58-f280-4f52-bdd5-a912551ce683} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractDays();) 2025.06.18 11:21:09.955103 [ 35675 ] {aaa1fb58-f280-4f52-bdd5-a912551ce683} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:09.992726 [ 35675 ] {1b167c6e-b660-4122-b05a-3e7fa2183c5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractHours();) 2025.06.18 11:21:09.997522 [ 35675 ] {1b167c6e-b660-4122-b05a-3e7fa2183c5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.020893 [ 35675 ] {01fb051b-3e8d-4a46-b5d6-98abc4702feb} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 0, should be 2: In scope SELECT subtractInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractInterval();) 2025.06.18 11:21:10.024258 [ 35675 ] {01fb051b-3e8d-4a46-b5d6-98abc4702feb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 0, should be 2: In scope SELECT subtractInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.047426 [ 35675 ] {fa4538f5-e94f-41d1-bc80-4dd8e3a37330} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMicroseconds();) 2025.06.18 11:21:10.051223 [ 35675 ] {fa4538f5-e94f-41d1-bc80-4dd8e3a37330} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.079839 [ 35675 ] {82975456-0b95-4d52-9ec7-6dddf84a3b71} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMilliseconds();) 2025.06.18 11:21:10.083732 [ 35675 ] {82975456-0b95-4d52-9ec7-6dddf84a3b71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.106894 [ 35675 ] {22818b6f-87f7-4704-9050-34b2505b41c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMinutes();) 2025.06.18 11:21:10.110595 [ 35675 ] {22818b6f-87f7-4704-9050-34b2505b41c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.134237 [ 35047 ] {1f65ad6a-cb1c-4e5c-9d12-200768946a10} executeQuery: Code: 403. DB::Exception: JOIN ALL INNER JOIN ... ON (t1.id = t2.id) AND (t1.id >= t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: -- non-equi condition containing columns from different tables doesn't supported yet SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id >= t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.135109 [ 35675 ] {de41a0fe-464d-45d4-872a-7142ceb3094e} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMonths();) 2025.06.18 11:21:10.136736 [ 35047 ] {1f65ad6a-cb1c-4e5c-9d12-200768946a10} TCPHandler: Code: 403. DB::Exception: JOIN ALL INNER JOIN ... ON (t1.id = t2.id) AND (t1.id >= t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.138557 [ 35675 ] {de41a0fe-464d-45d4-872a-7142ceb3094e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.164683 [ 35675 ] {195e912f-ebaa-4fe7-bb3c-cd558c355e1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractNanoseconds();) 2025.06.18 11:21:10.169326 [ 35675 ] {195e912f-ebaa-4fe7-bb3c-cd558c355e1c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.193854 [ 35675 ] {0a89ace8-37ce-467c-86a2-eccd435c382a} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractQuarters();) 2025.06.18 11:21:10.197441 [ 35675 ] {0a89ace8-37ce-467c-86a2-eccd435c382a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.199005 [ 35659 ] {b441c16f-e249-484b-93f2-992175bebc11} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT generateSnowflakeID(NULL, NULL);) 2025.06.18 11:21:10.202915 [ 35659 ] {b441c16f-e249-484b-93f2-992175bebc11} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:10.205237 [ 35047 ] {081d20ae-b52b-49f0-97a1-ad56b2360220} executeQuery: Code: 403. DB::Exception: JOIN ANY INNER JOIN ... ON (t1.id = t2.id) AND (t2.key = t2.key2) AND (t1.key = t1.key2) AND (t1.id >= length(t2.key)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND t1.id >= length(t2.key);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.207615 [ 35047 ] {081d20ae-b52b-49f0-97a1-ad56b2360220} TCPHandler: Code: 403. DB::Exception: JOIN ANY INNER JOIN ... ON (t1.id = t2.id) AND (t2.key = t2.key2) AND (t1.key = t1.key2) AND (t1.id >= length(t2.key)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.220894 [ 35675 ] {d3d6dfa1-6da0-4f9b-a51d-1635c47c167c} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractSeconds();) 2025.06.18 11:21:10.224203 [ 35675 ] {d3d6dfa1-6da0-4f9b-a51d-1635c47c167c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.247210 [ 35675 ] {c1426ca6-561b-453b-a84a-20ef00757556} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT subtractTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractTupleOfIntervals();) 2025.06.18 11:21:10.250836 [ 35675 ] {c1426ca6-561b-453b-a84a-20ef00757556} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT subtractTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.274596 [ 35675 ] {71966e04-18bc-4278-ae5b-ef135624ecda} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractWeeks();) 2025.06.18 11:21:10.284689 [ 35659 ] {db03e052-d3e8-4c5f-842a-d61879131095} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT generateUUIDv4(NULL, NULL);) 2025.06.18 11:21:10.337090 [ 35675 ] {71966e04-18bc-4278-ae5b-ef135624ecda} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.338053 [ 35659 ] {db03e052-d3e8-4c5f-842a-d61879131095} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.361626 [ 35675 ] {0da72761-71a6-4a27-95c9-eb538a0e552b} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractYears();) 2025.06.18 11:21:10.365547 [ 35675 ] {0da72761-71a6-4a27-95c9-eb538a0e552b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.369575 [ 35659 ] {968c1bca-3983-4f6b-b9ae-dd6acdd55596} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT generateUUIDv7(NULL, NULL);) 2025.06.18 11:21:10.372893 [ 35659 ] {968c1bca-3983-4f6b-b9ae-dd6acdd55596} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.388684 [ 35675 ] {7344be41-afd0-4dc2-ba13-90bc37387dd1} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sum();) 2025.06.18 11:21:10.392419 [ 35675 ] {7344be41-afd0-4dc2-ba13-90bc37387dd1} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.403105 [ 35659 ] {559a0b32-b31d-4ee7-92ff-1f28bf113591} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geoDistance(NULL, NULL);) 2025.06.18 11:21:10.406685 [ 35659 ] {559a0b32-b31d-4ee7-92ff-1f28bf113591} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.414187 [ 35675 ] {ac1407c4-02fd-4545-84ee-1d746d36288b} executeQuery: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumCount();) 2025.06.18 11:21:10.418034 [ 35675 ] {ac1407c4-02fd-4545-84ee-1d746d36288b} TCPHandler: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.434839 [ 35659 ] {36535d99-2bc4-4c59-9eef-44916a6b0204} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geoToH3(NULL, NULL);) 2025.06.18 11:21:10.438237 [ 35047 ] {aed7cc02-9026-41d5-aad4-ba848ddd3c65} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t22.key = t22.key2) OR (t1.id = t22.id)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON t1.id == t22.idd and (t22.key == t22.key2 OR t1.id == t22.id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.438540 [ 35659 ] {36535d99-2bc4-4c59-9eef-44916a6b0204} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.439630 [ 35675 ] {03f7ed59-9d2e-40fc-b6c1-302f14867a9f} executeQuery: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumKahan();) 2025.06.18 11:21:10.440751 [ 35047 ] {aed7cc02-9026-41d5-aad4-ba848ddd3c65} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t22.key = t22.key2) OR (t1.id = t22.id)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.442774 [ 35675 ] {03f7ed59-9d2e-40fc-b6c1-302f14867a9f} TCPHandler: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.467110 [ 35675 ] {d0ca1fe0-af13-4022-9570-3ee1e73dc6af} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapFiltered requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMapFiltered();) 2025.06.18 11:21:10.471076 [ 35675 ] {d0ca1fe0-af13-4022-9570-3ee1e73dc6af} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapFiltered requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.495062 [ 35675 ] {2cd6c2c8-825e-42a2-8941-474b8468487b} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapFilteredWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMapFilteredWithOverflow();) 2025.06.18 11:21:10.498563 [ 35675 ] {2cd6c2c8-825e-42a2-8941-474b8468487b} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapFilteredWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.502734 [ 35047 ] {449c7e0f-2119-43f9-8ae0-fd121307ad3d} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t1.id = t22.id) OR (t22.key = t22.key2)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON t1.id == t22.idd and (t1.id == t22.id OR t22.key == t22.key2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.505016 [ 35047 ] {449c7e0f-2119-43f9-8ae0-fd121307ad3d} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t1.id = t22.id) OR (t22.key = t22.key2)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.521115 [ 35675 ] {379b2896-33f6-4f7f-a56a-9f5a76e98dda} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMapWithOverflow();) 2025.06.18 11:21:10.524788 [ 35675 ] {379b2896-33f6-4f7f-a56a-9f5a76e98dda} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.527686 [ 35659 ] {72003890-4ec3-4dcd-a2a4-bc9123946f32} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geohashDecode(NULL, NULL);) 2025.06.18 11:21:10.531255 [ 35659 ] {72003890-4ec3-4dcd-a2a4-bc9123946f32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.545956 [ 35675 ] {6667bf26-7883-43ab-801f-eca4bff10f50} executeQuery: Code: 42. DB::Exception: Aggregate function sumMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMappedArrays();) 2025.06.18 11:21:10.549268 [ 35675 ] {6667bf26-7883-43ab-801f-eca4bff10f50} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.563822 [ 35047 ] {917c1207-4ec3-4bb7-aa26-622ddfee7de8} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t22.key = t22.key2) OR (t1.id = t22.id)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON (t22.key == t22.key2 OR t1.id == t22.id) and t1.id == t22.idd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.566114 [ 35047 ] {917c1207-4ec3-4bb7-aa26-622ddfee7de8} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t22.key = t22.key2) OR (t1.id = t22.id)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.570759 [ 35675 ] {c48182c4-ceb8-4691-9ce6-13b1d84d4d08} executeQuery: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumWithOverflow();) 2025.06.18 11:21:10.574020 [ 35675 ] {c48182c4-ceb8-4691-9ce6-13b1d84d4d08} TCPHandler: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.596729 [ 35675 ] {db92da87-269e-4bd9-b459-4fe85fbd4460} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT svg();) 2025.06.18 11:21:10.600563 [ 35675 ] {db92da87-269e-4bd9-b459-4fe85fbd4460} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.617542 [ 35659 ] {1d567f29-9acc-4c68-a99d-43d0f8af918f} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geohashesInBox(NULL, NULL);) 2025.06.18 11:21:10.621237 [ 35659 ] {1d567f29-9acc-4c68-a99d-43d0f8af918f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.626098 [ 35675 ] {31e38864-b5a2-4c15-83ce-52495c27df5b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT synonyms();) 2025.06.18 11:21:10.630289 [ 35675 ] {31e38864-b5a2-4c15-83ce-52495c27df5b} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:10.630855 [ 35047 ] {ed67fe01-ce9e-49b9-b736-e12d4cfe8536} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON (t1.id == t22.id OR t22.key == t22.key2) and t1.id == t22.idd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.632970 [ 35047 ] {ed67fe01-ce9e-49b9-b736-e12d4cfe8536} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.651552 [ 35659 ] {05d0eba1-5983-4880-ba15-8619dab0bc4b} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getClientHTTPHeader(NULL, NULL);) 2025.06.18 11:21:10.654970 [ 35659 ] {05d0eba1-5983-4880-ba15-8619dab0bc4b} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.18 11:21:10.657458 [ 35675 ] {cb7128fe-70fe-4c5d-a755-79c8c0f2a966} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 0, should be 1: In scope SELECT tan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tan();) 2025.06.18 11:21:10.660945 [ 35675 ] {cb7128fe-70fe-4c5d-a755-79c8c0f2a966} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 0, should be 1: In scope SELECT tan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.682517 [ 35675 ] {572f1d38-72bd-45e2-89f3-8fd3c2cd1b55} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 0, should be 1: In scope SELECT tanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tanh();) 2025.06.18 11:21:10.682893 [ 35659 ] {d5a8308c-100f-4fd2-ab0b-4a64393556f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getMacro(NULL, NULL);) 2025.06.18 11:21:10.685979 [ 35675 ] {572f1d38-72bd-45e2-89f3-8fd3c2cd1b55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 0, should be 1: In scope SELECT tanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.686251 [ 35659 ] {d5a8308c-100f-4fd2-ab0b-4a64393556f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.714638 [ 35659 ] {0143832b-83e0-455f-a02b-950fc6c6daeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getOSKernelVersion(NULL, NULL);) 2025.06.18 11:21:10.718156 [ 35659 ] {0143832b-83e0-455f-a02b-950fc6c6daeb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.748025 [ 35659 ] {eb2d9b35-8191-4dcd-90b8-a419bf70c25d} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getServerPort(NULL, NULL);) 2025.06.18 11:21:10.750361 [ 35047 ] {a7d7d9a2-060c-46e7-a32a-62ad510793d4} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND ((t1.id = t22.idd) AND ((t1.key2 = 'a1') OR (t1.key2 = 'a2') OR (t1.key2 = 'a3') OR (t1.key2 = 'a4') OR (t1.key2 = 'a5') OR (t1.key2 = 'a6') OR (t1.key2 = 'a7') OR (t1.key2 = 'a8') OR (t1.key2 = 'a9') OR (t1.key2 = 'a10') OR (t1.key2 = 'a11') OR (t1.key2 = 'a12') OR (t1.key2 = 'a13') OR (t1.key2 = 'a14') OR (t1.key2 = 'a15') OR (t1.key2 = 'a16') OR (t1.key2 = 'a17') OR (t1.key2 = 'a18') OR (t1.key2 = 'a19') OR (t1.key2 = '111'))) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON (t1.id == t22.id OR t22.key == t22.key2) and (t1.id == t22.idd AND (t1.key2 = 'a1' OR t1.key2 = 'a2' OR t1.key2 = 'a3' OR t1.key2 = 'a4' OR t1.key2 = 'a5' OR t1.key2 = 'a6' OR t1.key2 = 'a7' OR t1.key2 = 'a8' OR t1.key2 = 'a9' OR t1.key2 = 'a10' OR t1.key2 = 'a11' OR t1.key2 = 'a12' OR t1.key2 = 'a13' OR t1.key2 = 'a14' OR t1.key2 = 'a15' OR t1.key2 = 'a16' OR t1.key2 = 'a17' OR t1.key2 = 'a18' OR t1.key2 = 'a19' OR t1.key2 = '111'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.751671 [ 35659 ] {eb2d9b35-8191-4dcd-90b8-a419bf70c25d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.753631 [ 35047 ] {a7d7d9a2-060c-46e7-a32a-62ad510793d4} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND ((t1.id = t22.idd) AND ((t1.key2 = 'a1') OR (t1.key2 = 'a2') OR (t1.key2 = 'a3') OR (t1.key2 = 'a4') OR (t1.key2 = 'a5') OR (t1.key2 = 'a6') OR (t1.key2 = 'a7') OR (t1.key2 = 'a8') OR (t1.key2 = 'a9') OR (t1.key2 = 'a10') OR (t1.key2 = 'a11') OR (t1.key2 = 'a12') OR (t1.key2 = 'a13') OR (t1.key2 = 'a14') OR (t1.key2 = 'a15') OR (t1.key2 = 'a16') OR (t1.key2 = 'a17') OR (t1.key2 = 'a18') OR (t1.key2 = 'a19') OR (t1.key2 = '111'))) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:10.755070 [ 35675 ] {bf428b5c-96b5-4801-b01a-18e2b860c0ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 0, should be 2: In scope SELECT test_function(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT test_function();) 2025.06.18 11:21:10.758686 [ 35675 ] {bf428b5c-96b5-4801-b01a-18e2b860c0ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 0, should be 2: In scope SELECT test_function(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.779955 [ 35675 ] {cda31d67-2516-452c-bae1-40837053a28b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 0, should be 1: In scope SELECT tgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tgamma();) 2025.06.18 11:21:10.779955 [ 35659 ] {fd62b8a2-319a-46d7-80b8-a1aa4df11c33} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getSetting(NULL, NULL);) 2025.06.18 11:21:10.783399 [ 35675 ] {cda31d67-2516-452c-bae1-40837053a28b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 0, should be 1: In scope SELECT tgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.783400 [ 35659 ] {fd62b8a2-319a-46d7-80b8-a1aa4df11c33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.805620 [ 35675 ] {57d893ba-9113-489a-8561-dda52cfcc609} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT theilsU();) 2025.06.18 11:21:10.809227 [ 35675 ] {57d893ba-9113-489a-8561-dda52cfcc609} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.814434 [ 35659 ] {245b9f54-cc6f-448f-8edf-874c556c9165} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getSizeOfEnumType(NULL, NULL);) 2025.06.18 11:21:10.818243 [ 35659 ] {245b9f54-cc6f-448f-8edf-874c556c9165} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.831275 [ 35675 ] {83d63daa-c8d8-46e2-b64e-4038f88de4aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 0, should be 1 or 2: In scope SELECT throwIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT throwIf();) 2025.06.18 11:21:10.835177 [ 35675 ] {83d63daa-c8d8-46e2-b64e-4038f88de4aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 0, should be 1 or 2: In scope SELECT throwIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.904124 [ 35675 ] {b4124fc3-931b-4fcc-bd10-72eb3ea7a95d} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 0, should be 2: In scope SELECT timeDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeDiff();) 2025.06.18 11:21:10.904124 [ 35659 ] {1dc44132-a8c6-464c-8bde-2de0c25b99d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getTypeSerializationStreams(NULL, NULL);) 2025.06.18 11:21:10.907956 [ 35675 ] {b4124fc3-931b-4fcc-bd10-72eb3ea7a95d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 0, should be 2: In scope SELECT timeDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.907980 [ 35659 ] {1dc44132-a8c6-464c-8bde-2de0c25b99d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.929369 [ 35675 ] {c1836727-b9af-4529-ae24-f517dede5725} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 0, should be 1 or 2: In scope SELECT timeSlot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeSlot();) 2025.06.18 11:21:10.932243 [ 35675 ] {c1836727-b9af-4529-ae24-f517dede5725} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 0, should be 1 or 2: In scope SELECT timeSlot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:10.953710 [ 35675 ] {5a726f75-d972-40e6-b2d9-cd3ce07ef270} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 0, should be 2 or 3: In scope SELECT timeSlots(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeSlots();) 2025.06.18 11:21:10.957066 [ 35675 ] {5a726f75-d972-40e6-b2d9-cd3ce07ef270} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 0, should be 2 or 3: In scope SELECT timeSlots(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.027861 [ 35675 ] {c00657e5-80fe-4757-b604-d51d3c626b70} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timeZoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeZoneOf();) 2025.06.18 11:21:11.031376 [ 35675 ] {c00657e5-80fe-4757-b604-d51d3c626b70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timeZoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.058624 [ 35675 ] {16c07458-b7db-4990-b652-a5a3907d2ab2} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timeZoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeZoneOffset();) 2025.06.18 11:21:11.062709 [ 35675 ] {16c07458-b7db-4990-b652-a5a3907d2ab2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timeZoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.089721 [ 35675 ] {8f5b69ee-00f8-4174-9618-af072c43fbc1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timestamp();) 2025.06.18 11:21:11.093973 [ 35675 ] {8f5b69ee-00f8-4174-9618-af072c43fbc1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.122146 [ 35675 ] {08d97a27-0eda-44e8-8780-d690107f7b64} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timestampDiff();) 2025.06.18 11:21:11.126719 [ 35675 ] {08d97a27-0eda-44e8-8780-d690107f7b64} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.154703 [ 35675 ] {354cfcfa-1fa0-430c-8a11-ef239ee52210} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timestamp_diff();) 2025.06.18 11:21:11.158810 [ 35675 ] {354cfcfa-1fa0-430c-8a11-ef239ee52210} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.234304 [ 35675 ] {d3337130-2c7f-411c-8cfa-1118ab5db97f} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timezoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timezoneOf();) 2025.06.18 11:21:11.238191 [ 35675 ] {d3337130-2c7f-411c-8cfa-1118ab5db97f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timezoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.262304 [ 35675 ] {1640624a-69cd-4f8c-8c2d-d48ce526f638} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timezoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timezoneOffset();) 2025.06.18 11:21:11.266431 [ 35675 ] {1640624a-69cd-4f8c-8c2d-d48ce526f638} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timezoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.292240 [ 35675 ] {79a019e6-e406-4605-8462-06b287beabdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 0, should be 1: In scope SELECT toBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toBool();) 2025.06.18 11:21:11.293932 [ 35671 ] {cc79bd8f-ca61-4790-aea3-a8edc030629f} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46100) (comment: 02293_grouping_function_group_by.sql) (in query: SELECT number, grouping(number, number % 2) as gr FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY CUBE(number, number % 2) WITH TOTALS HAVING grouping(number) != 0 ORDER BY number, gr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:11.296216 [ 35671 ] {cc79bd8f-ca61-4790-aea3-a8edc030629f} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:11.296302 [ 35675 ] {79a019e6-e406-4605-8462-06b287beabdf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 0, should be 1: In scope SELECT toBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.318370 [ 35675 ] {c85e95fb-8688-4065-b9e7-bf08450af3bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 0, should be 1: In scope SELECT toColumnTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toColumnTypeName();) 2025.06.18 11:21:11.321748 [ 35675 ] {c85e95fb-8688-4065-b9e7-bf08450af3bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 0, should be 1: In scope SELECT toColumnTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.342620 [ 35675 ] {588b7530-8954-49db-8efb-0c11e813d54d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate();) 2025.06.18 11:21:11.346200 [ 35675 ] {588b7530-8954-49db-8efb-0c11e813d54d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.368766 [ 35675 ] {c4ed093b-43d0-4746-9cbf-a071a5168e29} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32();) 2025.06.18 11:21:11.373015 [ 35675 ] {c4ed093b-43d0-4746-9cbf-a071a5168e29} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.398128 [ 35675 ] {3bee64a0-9ea5-44b7-838f-0ddb3d3de6d6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32OrDefault();) 2025.06.18 11:21:11.399843 [ 35659 ] {8e05e1d2-15cf-4ab9-9546-6b1280dbaa81} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT globalVariable(NULL, NULL);) 2025.06.18 11:21:11.402428 [ 35675 ] {3bee64a0-9ea5-44b7-838f-0ddb3d3de6d6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.403771 [ 35659 ] {8e05e1d2-15cf-4ab9-9546-6b1280dbaa81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.422401 [ 35675 ] {37475a83-c876-4700-8f8e-21f1d2b522a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32OrNull();) 2025.06.18 11:21:11.426300 [ 35675 ] {37475a83-c876-4700-8f8e-21f1d2b522a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.434955 [ 35659 ] {484080e7-9eaa-467c-bf09-fc96a242c9d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT greatCircleAngle(NULL, NULL);) 2025.06.18 11:21:11.438992 [ 35659 ] {484080e7-9eaa-467c-bf09-fc96a242c9d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.447747 [ 35675 ] {f526cc72-e0b8-4dfb-82f1-6436890d59b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32OrZero();) 2025.06.18 11:21:11.451368 [ 35675 ] {f526cc72-e0b8-4dfb-82f1-6436890d59b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.467962 [ 35659 ] {1ff36cc2-07ae-4370-a0df-cd8b09962070} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT greatCircleDistance(NULL, NULL);) 2025.06.18 11:21:11.471644 [ 35659 ] {1ff36cc2-07ae-4370-a0df-cd8b09962070} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.474065 [ 35675 ] {677478ab-ae20-4b77-a832-e47e53b625be} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateOrDefault();) 2025.06.18 11:21:11.477623 [ 35675 ] {677478ab-ae20-4b77-a832-e47e53b625be} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.501432 [ 35675 ] {d07158bb-3a3c-4de9-b693-d2834a6f19f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateOrNull();) 2025.06.18 11:21:11.505233 [ 35675 ] {d07158bb-3a3c-4de9-b693-d2834a6f19f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.526865 [ 35675 ] {a8d7910e-3231-4aa5-b3a5-3e21de046137} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateOrZero();) 2025.06.18 11:21:11.530370 [ 35675 ] {a8d7910e-3231-4aa5-b3a5-3e21de046137} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.556747 [ 35675 ] {518bd4ed-a7ae-4046-989d-b04cc959f71b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime();) 2025.06.18 11:21:11.560448 [ 35675 ] {518bd4ed-a7ae-4046-989d-b04cc959f71b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.582207 [ 35675 ] {21f5f422-18fa-446e-b711-f971d20be5be} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime32();) 2025.06.18 11:21:11.585945 [ 35675 ] {21f5f422-18fa-446e-b711-f971d20be5be} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.610029 [ 35675 ] {c8dfd412-842c-439b-9c96-56550c8d8ff4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64();) 2025.06.18 11:21:11.613656 [ 35675 ] {c8dfd412-842c-439b-9c96-56550c8d8ff4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.636985 [ 35675 ] {fee14090-096c-4546-a654-c2429ab0b704} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64OrDefault();) 2025.06.18 11:21:11.640472 [ 35675 ] {fee14090-096c-4546-a654-c2429ab0b704} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.665744 [ 35675 ] {2061751c-d1fa-49af-8b39-744eda98c6d5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64OrNull();) 2025.06.18 11:21:11.670928 [ 35675 ] {2061751c-d1fa-49af-8b39-744eda98c6d5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.695973 [ 35675 ] {b5d8f24e-344c-4c1e-81b4-db8eb597a9cd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64OrZero();) 2025.06.18 11:21:11.700171 [ 35675 ] {b5d8f24e-344c-4c1e-81b4-db8eb597a9cd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.720344 [ 35671 ] {2ef29da4-7e67-4e08-9b70-82a914813f4d} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46100) (comment: 02293_grouping_function_group_by.sql) (in query: SELECT number, grouping(number, number % 2) as gr FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY ROLLUP(number, number % 2) WITH TOTALS HAVING grouping(number) != 0 ORDER BY number, gr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:11.722849 [ 35671 ] {2ef29da4-7e67-4e08-9b70-82a914813f4d} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:11.727600 [ 35675 ] {ac6a3c8f-20a8-42e9-a272-f7e759a67a10} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTimeOrDefault'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTimeOrDefault();) 2025.06.18 11:21:11.731586 [ 35675 ] {ac6a3c8f-20a8-42e9-a272-f7e759a67a10} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTimeOrDefault'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.756416 [ 35675 ] {d4a1f210-4e03-44f9-b95e-c7bc19fbdb70} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTimeOrNull();) 2025.06.18 11:21:11.760141 [ 35675 ] {d4a1f210-4e03-44f9-b95e-c7bc19fbdb70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.783956 [ 35675 ] {b2bb5290-1a23-4848-9fa6-b66cfb25ab56} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTimeOrZero();) 2025.06.18 11:21:11.787700 [ 35675 ] {b2bb5290-1a23-4848-9fa6-b66cfb25ab56} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.811584 [ 35675 ] {a991e7b3-ea76-47ed-8ebc-d83493666a2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDayOfMonth();) 2025.06.18 11:21:11.815354 [ 35675 ] {a991e7b3-ea76-47ed-8ebc-d83493666a2c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.838715 [ 35675 ] {fa3215f2-491b-4334-876b-27f1d1d9d290} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDayOfWeek();) 2025.06.18 11:21:11.842848 [ 35675 ] {fa3215f2-491b-4334-876b-27f1d1d9d290} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.865994 [ 35675 ] {a8930b39-c674-49cb-a1eb-c913dd2a57c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDayOfYear();) 2025.06.18 11:21:11.869867 [ 35675 ] {a8930b39-c674-49cb-a1eb-c913dd2a57c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.877651 [ 35047 ] {a84a5996-7494-4da7-a9ef-c69843224ace} executeQuery: Code: 10. DB::Exception: Not found column id in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT t1.key FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000003325c54e 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fe00 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:11.880549 [ 35047 ] {a84a5996-7494-4da7-a9ef-c69843224ace} TCPHandler: Code: 10. DB::Exception: Not found column id in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000003325c54e 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fe00 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:11.893181 [ 35675 ] {31970434-7d18-4a85-bccc-d5164e97c2f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDaysSinceYearZero();) 2025.06.18 11:21:11.896875 [ 35675 ] {31970434-7d18-4a85-bccc-d5164e97c2f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.920528 [ 35675 ] {5e61f3e5-b6a0-4026-a1e7-229950684254} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128();) 2025.06.18 11:21:11.924401 [ 35675 ] {5e61f3e5-b6a0-4026-a1e7-229950684254} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.947660 [ 35675 ] {ffd1a409-72a3-45d8-a900-1d9284259176} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128OrDefault();) 2025.06.18 11:21:11.951474 [ 35675 ] {ffd1a409-72a3-45d8-a900-1d9284259176} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:11.974744 [ 35675 ] {79b0ba65-caf3-48b0-b8c6-7752abded4c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128OrNull();) 2025.06.18 11:21:11.979043 [ 35675 ] {79b0ba65-caf3-48b0-b8c6-7752abded4c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.006653 [ 35675 ] {426e763e-d43e-43f8-8b01-3ea1ce5d65ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128OrZero();) 2025.06.18 11:21:12.011235 [ 35675 ] {426e763e-d43e-43f8-8b01-3ea1ce5d65ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.041691 [ 35675 ] {23e4d3e3-a3be-4cd7-878a-4521cdf50762} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256();) 2025.06.18 11:21:12.046528 [ 35675 ] {23e4d3e3-a3be-4cd7-878a-4521cdf50762} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.069714 [ 35675 ] {c48361d2-8bb4-41f6-9f13-bb2206e3875f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256OrDefault();) 2025.06.18 11:21:12.073600 [ 35675 ] {c48361d2-8bb4-41f6-9f13-bb2206e3875f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.096669 [ 35675 ] {14f6b1a3-c5ff-4138-a415-30cac16f2d16} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256OrNull();) 2025.06.18 11:21:12.100412 [ 35675 ] {14f6b1a3-c5ff-4138-a415-30cac16f2d16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.123855 [ 35675 ] {c0a0e7be-a6aa-4f09-9fd5-03ecdf282956} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256OrZero();) 2025.06.18 11:21:12.127559 [ 35675 ] {c0a0e7be-a6aa-4f09-9fd5-03ecdf282956} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.151122 [ 35675 ] {ab40d025-b746-4217-9afd-5577accf2973} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32();) 2025.06.18 11:21:12.154790 [ 35675 ] {ab40d025-b746-4217-9afd-5577accf2973} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.178955 [ 35675 ] {deaba621-99aa-4c86-b8e6-eabe4e579f3b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32OrDefault();) 2025.06.18 11:21:12.182786 [ 35675 ] {deaba621-99aa-4c86-b8e6-eabe4e579f3b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.207413 [ 35675 ] {006331ed-ab53-40d0-bedb-c4580ff99de7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32OrNull();) 2025.06.18 11:21:12.211539 [ 35675 ] {006331ed-ab53-40d0-bedb-c4580ff99de7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.235429 [ 35675 ] {2990cefa-c61e-475b-a944-d53cd57f8c17} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32OrZero();) 2025.06.18 11:21:12.239158 [ 35675 ] {2990cefa-c61e-475b-a944-d53cd57f8c17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.263125 [ 35675 ] {2442c22d-7529-4ffe-a85a-86f15b4bb22f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64();) 2025.06.18 11:21:12.266891 [ 35675 ] {2442c22d-7529-4ffe-a85a-86f15b4bb22f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.291446 [ 35675 ] {760f7f63-d30d-4cfd-a2a6-d68d45a289f0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64OrDefault();) 2025.06.18 11:21:12.295225 [ 35675 ] {760f7f63-d30d-4cfd-a2a6-d68d45a289f0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.312607 [ 51918 ] {87c2f48e-214b-45fb-a686-3ffd223929fc} executeQuery: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40450) (comment: 01445_create_table_as_table_function.sh) (in query: CREATE TABLE system.columns AS numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:12.317129 [ 51918 ] {87c2f48e-214b-45fb-a686-3ffd223929fc} TCPHandler: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:12.318708 [ 35675 ] {1031422f-b2f8-4ad8-a480-dc92c560d23b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64OrNull();) 2025.06.18 11:21:12.322470 [ 35675 ] {1031422f-b2f8-4ad8-a480-dc92c560d23b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.345956 [ 35675 ] {1b585bfc-f9a8-4795-b88c-109508435b42} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64OrZero();) 2025.06.18 11:21:12.349952 [ 35675 ] {1b585bfc-f9a8-4795-b88c-109508435b42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.373481 [ 35675 ] {c1101069-7c6f-4b09-8c0d-b9db6e1cd752} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 0, should be 2: In scope SELECT toDecimalString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimalString();) 2025.06.18 11:21:12.377533 [ 35675 ] {c1101069-7c6f-4b09-8c0d-b9db6e1cd752} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 0, should be 2: In scope SELECT toDecimalString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.400789 [ 35675 ] {07469bba-f3ab-43c8-b697-137d49586b3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 0, should be 2: In scope SELECT toFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFixedString();) 2025.06.18 11:21:12.404907 [ 35675 ] {07469bba-f3ab-43c8-b697-137d49586b3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 0, should be 2: In scope SELECT toFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.428459 [ 35675 ] {0290c334-88f4-4ed6-8bda-e2fd599f735b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32();) 2025.06.18 11:21:12.432248 [ 35675 ] {0290c334-88f4-4ed6-8bda-e2fd599f735b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.454729 [ 35675 ] {43b064d7-6a3c-4680-8104-0405f87ea0c9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32OrDefault();) 2025.06.18 11:21:12.458579 [ 35675 ] {43b064d7-6a3c-4680-8104-0405f87ea0c9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.482162 [ 35675 ] {8fb633a0-fa01-4064-b5f9-9b793e5fcb31} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32OrNull();) 2025.06.18 11:21:12.486395 [ 35675 ] {8fb633a0-fa01-4064-b5f9-9b793e5fcb31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.510514 [ 35675 ] {9ab60cc3-07ca-4586-8097-92d4cc33c278} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32OrZero();) 2025.06.18 11:21:12.514268 [ 35675 ] {9ab60cc3-07ca-4586-8097-92d4cc33c278} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.537975 [ 35675 ] {d93652b4-5cbd-4aed-ae15-8ee41f8540a0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64();) 2025.06.18 11:21:12.542035 [ 35675 ] {d93652b4-5cbd-4aed-ae15-8ee41f8540a0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.564560 [ 35675 ] {30ab588a-ed6c-421d-a811-44a5819d1aee} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64OrDefault();) 2025.06.18 11:21:12.568214 [ 35675 ] {30ab588a-ed6c-421d-a811-44a5819d1aee} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.592630 [ 35675 ] {3081ee6e-63ca-4449-9f16-65bc099b3ec0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64OrNull();) 2025.06.18 11:21:12.596225 [ 35675 ] {3081ee6e-63ca-4449-9f16-65bc099b3ec0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.620500 [ 35675 ] {c1ae17fa-435e-45b6-8c04-7589e3ae3c21} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64OrZero();) 2025.06.18 11:21:12.627505 [ 35675 ] {c1ae17fa-435e-45b6-8c04-7589e3ae3c21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.653561 [ 35675 ] {407ab9f7-0424-409b-9939-dd81aec7e202} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toHour();) 2025.06.18 11:21:12.657802 [ 35675 ] {407ab9f7-0424-409b-9939-dd81aec7e202} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.681818 [ 35675 ] {2a3f56f8-c658-42e3-a5ea-a817d4256c73} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4();) 2025.06.18 11:21:12.685696 [ 35675 ] {2a3f56f8-c658-42e3-a5ea-a817d4256c73} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.709573 [ 35675 ] {c9af0895-8690-42a5-857a-06e0f5afede5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4OrDefault();) 2025.06.18 11:21:12.713664 [ 35675 ] {c9af0895-8690-42a5-857a-06e0f5afede5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.737552 [ 35675 ] {3f5cfb82-d62b-49b8-8c14-05a7bf74079c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4OrNull();) 2025.06.18 11:21:12.741625 [ 35675 ] {3f5cfb82-d62b-49b8-8c14-05a7bf74079c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.765122 [ 35675 ] {514e98b8-7af7-4acc-858a-4bcea8f612bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4OrZero();) 2025.06.18 11:21:12.768910 [ 35675 ] {514e98b8-7af7-4acc-858a-4bcea8f612bc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.792767 [ 35675 ] {e6bcba5d-9d1a-4c4c-8354-a20b6877cfdb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6();) 2025.06.18 11:21:12.796206 [ 35675 ] {e6bcba5d-9d1a-4c4c-8354-a20b6877cfdb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.819213 [ 35675 ] {edb4ca88-b8e1-4903-83b1-4f72416255a4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6OrDefault();) 2025.06.18 11:21:12.822788 [ 35675 ] {edb4ca88-b8e1-4903-83b1-4f72416255a4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.845057 [ 35675 ] {48e6dc14-d28f-4f8f-bf39-d08e93b4425d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6OrNull();) 2025.06.18 11:21:12.851550 [ 35675 ] {48e6dc14-d28f-4f8f-bf39-d08e93b4425d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.873515 [ 35675 ] {47e030a0-52cd-4c96-8039-23b4c165e1d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6OrZero();) 2025.06.18 11:21:12.877006 [ 35675 ] {47e030a0-52cd-4c96-8039-23b4c165e1d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.897684 [ 35675 ] {dfd07405-9b07-4195-8574-6a9a24e80fea} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toISOWeek();) 2025.06.18 11:21:12.901415 [ 35675 ] {dfd07405-9b07-4195-8574-6a9a24e80fea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.924299 [ 35675 ] {e52113c2-06aa-4f84-bf45-c4dbd2007b25} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toISOYear();) 2025.06.18 11:21:12.928287 [ 35675 ] {e52113c2-06aa-4f84-bf45-c4dbd2007b25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.951456 [ 35675 ] {e07ec959-e7b4-4e8f-8ab8-5527d996ab60} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128();) 2025.06.18 11:21:12.955057 [ 35675 ] {e07ec959-e7b4-4e8f-8ab8-5527d996ab60} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.964970 [ 35659 ] {7dd81c3f-3d05-4911-99d8-749894b0596d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3CellAreaM2(NULL, NULL);) 2025.06.18 11:21:12.968399 [ 35659 ] {7dd81c3f-3d05-4911-99d8-749894b0596d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.978281 [ 35675 ] {978edd55-a3d0-4ca6-a115-f34d6d94da20} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128OrDefault();) 2025.06.18 11:21:12.982330 [ 35675 ] {978edd55-a3d0-4ca6-a115-f34d6d94da20} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:12.995199 [ 35673 ] {3140ca9d-a1ec-4f44-b59b-d2da8d802978} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFC(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46226) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFC(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d9fe4d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:12.995997 [ 35659 ] {e255f23b-b33e-4837-8a14-458d15dda02e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3CellAreaRads2(NULL, NULL);) 2025.06.18 11:21:12.998106 [ 35673 ] {3140ca9d-a1ec-4f44-b59b-d2da8d802978} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFC(value). (CANNOT_NORMALIZE_STRING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d9fe4d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:12.999615 [ 35659 ] {e255f23b-b33e-4837-8a14-458d15dda02e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.004739 [ 35675 ] {62d0a0d8-e16a-40ad-bd92-5ce1561d505d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128OrNull();) 2025.06.18 11:21:13.007913 [ 35675 ] {62d0a0d8-e16a-40ad-bd92-5ce1561d505d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.025813 [ 35675 ] {37114282-72e9-422c-afbe-1b6efba2a6db} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128OrZero();) 2025.06.18 11:21:13.029547 [ 35675 ] {37114282-72e9-422c-afbe-1b6efba2a6db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.052290 [ 35675 ] {0ecae1d6-c0c7-41d7-9f43-2e798f215e56} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16();) 2025.06.18 11:21:13.056069 [ 35675 ] {0ecae1d6-c0c7-41d7-9f43-2e798f215e56} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.077510 [ 35659 ] {115a4e69-5228-4228-8fb4-0ac73912f2ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3EdgeAngle(NULL, NULL);) 2025.06.18 11:21:13.077510 [ 35675 ] {f7c16a85-8ea1-4ea3-80d6-5a7517cfcc78} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16OrDefault();) 2025.06.18 11:21:13.081136 [ 35659 ] {115a4e69-5228-4228-8fb4-0ac73912f2ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.081136 [ 35675 ] {f7c16a85-8ea1-4ea3-80d6-5a7517cfcc78} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.103932 [ 35675 ] {a4565d23-78b1-4622-b8a2-0ed8705fe1b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16OrNull();) 2025.06.18 11:21:13.106973 [ 35659 ] {35420f6d-87c2-4988-a9fb-154af46cfbd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3EdgeLengthKm(NULL, NULL);) 2025.06.18 11:21:13.107645 [ 35675 ] {a4565d23-78b1-4622-b8a2-0ed8705fe1b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.110104 [ 35659 ] {35420f6d-87c2-4988-a9fb-154af46cfbd5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.135143 [ 35659 ] {cbbcc9f6-d9bc-4fcd-bcc6-44d72a96245e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3EdgeLengthM(NULL, NULL);) 2025.06.18 11:21:13.137063 [ 35675 ] {ca1cb70c-2f40-472b-9f75-0aa346b3f083} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16OrZero();) 2025.06.18 11:21:13.138563 [ 35659 ] {cbbcc9f6-d9bc-4fcd-bcc6-44d72a96245e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.141176 [ 35675 ] {ca1cb70c-2f40-472b-9f75-0aa346b3f083} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.163691 [ 35675 ] {01227a04-f1c2-4e3e-8886-1efe64f8c2e2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256();) 2025.06.18 11:21:13.164779 [ 35659 ] {86195996-2335-40c5-8a6f-64bdbbc6c432} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL);) 2025.06.18 11:21:13.167745 [ 35675 ] {01227a04-f1c2-4e3e-8886-1efe64f8c2e2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.168321 [ 35659 ] {86195996-2335-40c5-8a6f-64bdbbc6c432} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.191010 [ 35675 ] {2f5c29ac-79ec-483e-a188-5ded4cdc91bf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256OrDefault();) 2025.06.18 11:21:13.195199 [ 35675 ] {2f5c29ac-79ec-483e-a188-5ded4cdc91bf} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.195758 [ 35659 ] {2d78fd7f-a2b2-4210-a90b-34a6996d6d2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL);) 2025.06.18 11:21:13.207931 [ 35659 ] {2d78fd7f-a2b2-4210-a90b-34a6996d6d2d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.218471 [ 35675 ] {50ac93c1-b34a-4d83-b7e5-996dea6a7768} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256OrNull();) 2025.06.18 11:21:13.222522 [ 35675 ] {50ac93c1-b34a-4d83-b7e5-996dea6a7768} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.236247 [ 35659 ] {9084dc47-cfdf-4d67-8b29-aa5a871a9c39} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL);) 2025.06.18 11:21:13.239950 [ 35659 ] {9084dc47-cfdf-4d67-8b29-aa5a871a9c39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.250780 [ 35675 ] {b43cd4b1-9ed2-480b-9e08-12b171935693} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256OrZero();) 2025.06.18 11:21:13.255211 [ 35675 ] {b43cd4b1-9ed2-480b-9e08-12b171935693} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.268467 [ 35659 ] {e9a3edb6-3b4a-407d-9459-0bce387aee83} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetBaseCell(NULL, NULL);) 2025.06.18 11:21:13.272953 [ 35659 ] {e9a3edb6-3b4a-407d-9459-0bce387aee83} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.289805 [ 35675 ] {8cc1a61c-baa6-49c7-ad76-71cae491f5fa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32();) 2025.06.18 11:21:13.295493 [ 35675 ] {8cc1a61c-baa6-49c7-ad76-71cae491f5fa} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.304469 [ 35659 ] {02ee68fb-fb41-4d04-a2b1-5e2c40d6f765} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL);) 2025.06.18 11:21:13.308883 [ 35659 ] {02ee68fb-fb41-4d04-a2b1-5e2c40d6f765} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.327764 [ 35675 ] {b0b655cb-28ff-4009-a4b2-9ef492ca225d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32OrDefault();) 2025.06.18 11:21:13.332095 [ 35675 ] {b0b655cb-28ff-4009-a4b2-9ef492ca225d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.341783 [ 35659 ] {49cc52c7-60e6-4daf-a22c-c5bea878ee74} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetFaces(NULL, NULL);) 2025.06.18 11:21:13.346491 [ 35659 ] {49cc52c7-60e6-4daf-a22c-c5bea878ee74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.359421 [ 35675 ] {d8452103-0b6a-4cfa-a6ca-c8305e0e8a67} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32OrNull();) 2025.06.18 11:21:13.363008 [ 35675 ] {d8452103-0b6a-4cfa-a6ca-c8305e0e8a67} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.374647 [ 35659 ] {58b81bce-7950-4cdc-9192-e5e0f911d8e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL);) 2025.06.18 11:21:13.378422 [ 35659 ] {58b81bce-7950-4cdc-9192-e5e0f911d8e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.386377 [ 35675 ] {3af4fe54-8a16-489f-aaeb-4d6ed2705a50} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32OrZero();) 2025.06.18 11:21:13.390315 [ 35675 ] {3af4fe54-8a16-489f-aaeb-4d6ed2705a50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.408953 [ 35659 ] {902914d6-6cb4-438c-8e56-64c1d7a69157} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL);) 2025.06.18 11:21:13.412205 [ 35675 ] {0a5b1803-32da-4cc2-9872-734a3a161715} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64();) 2025.06.18 11:21:13.412693 [ 35659 ] {902914d6-6cb4-438c-8e56-64c1d7a69157} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.415627 [ 35675 ] {0a5b1803-32da-4cc2-9872-734a3a161715} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.438002 [ 35675 ] {5ad49e11-fbb6-420d-9b3b-f8abfa42a055} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64OrDefault();) 2025.06.18 11:21:13.442147 [ 35675 ] {5ad49e11-fbb6-420d-9b3b-f8abfa42a055} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.443417 [ 35659 ] {675cdd8f-5054-4e02-bdd8-e0404464fc4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetPentagonIndexes(NULL, NULL);) 2025.06.18 11:21:13.447148 [ 35659 ] {675cdd8f-5054-4e02-bdd8-e0404464fc4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.465830 [ 35675 ] {7b19d2b9-5c96-4577-b42c-94e2b0f5eb76} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64OrNull();) 2025.06.18 11:21:13.469578 [ 35675 ] {7b19d2b9-5c96-4577-b42c-94e2b0f5eb76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.476959 [ 35659 ] {2a4ad968-997a-4701-a959-6bb67ac9d099} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetRes0Indexes(NULL, NULL);) 2025.06.18 11:21:13.480541 [ 35659 ] {2a4ad968-997a-4701-a959-6bb67ac9d099} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.492777 [ 35675 ] {0eddf132-23ff-4a39-808e-df024692ba7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64OrZero();) 2025.06.18 11:21:13.496549 [ 35675 ] {0eddf132-23ff-4a39-808e-df024692ba7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.507892 [ 35659 ] {f824e6b2-355d-40a5-aa3d-eb8e7a4db83d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetResolution(NULL, NULL);) 2025.06.18 11:21:13.511260 [ 35659 ] {f824e6b2-355d-40a5-aa3d-eb8e7a4db83d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.520518 [ 35675 ] {5cb613a8-05f6-4ce0-b10b-83cf78d1321b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8();) 2025.06.18 11:21:13.524159 [ 35675 ] {5cb613a8-05f6-4ce0-b10b-83cf78d1321b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.547346 [ 35675 ] {98ada67c-3b85-4496-8e83-b8f786f54a6f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8OrDefault();) 2025.06.18 11:21:13.550954 [ 35675 ] {98ada67c-3b85-4496-8e83-b8f786f54a6f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.572718 [ 35675 ] {4b58312a-c999-48d3-ae96-6650f9d95703} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8OrNull();) 2025.06.18 11:21:13.576158 [ 35675 ] {4b58312a-c999-48d3-ae96-6650f9d95703} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.590396 [ 35659 ] {a6e14e65-c430-4d27-ab83-98ac1c6ee467} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL);) 2025.06.18 11:21:13.594121 [ 35659 ] {a6e14e65-c430-4d27-ab83-98ac1c6ee467} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.597637 [ 35675 ] {980ef03e-bcd5-4538-837f-99e5a5169e10} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8OrZero();) 2025.06.18 11:21:13.601226 [ 35675 ] {980ef03e-bcd5-4538-837f-99e5a5169e10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.621557 [ 35659 ] {9b4f5aa1-f77c-4c4d-98eb-e988acd2f9e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL);) 2025.06.18 11:21:13.622948 [ 35675 ] {dd87f20c-7d36-40d5-95ae-0e8ea96c8214} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalDay();) 2025.06.18 11:21:13.625473 [ 35659 ] {9b4f5aa1-f77c-4c4d-98eb-e988acd2f9e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.626839 [ 35675 ] {dd87f20c-7d36-40d5-95ae-0e8ea96c8214} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.650514 [ 35675 ] {232cf6d8-ebc5-4d3e-93c7-a32ba5fa02fc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalHour();) 2025.06.18 11:21:13.652057 [ 35659 ] {8fa7bbba-2376-4e2d-878e-d8af38c13a80} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3HexAreaKm2(NULL, NULL);) 2025.06.18 11:21:13.654601 [ 35675 ] {232cf6d8-ebc5-4d3e-93c7-a32ba5fa02fc} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.656154 [ 35659 ] {8fa7bbba-2376-4e2d-878e-d8af38c13a80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.677615 [ 35675 ] {a3eb7735-cd14-4381-89a8-f1129178e222} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMicrosecond();) 2025.06.18 11:21:13.681226 [ 35675 ] {a3eb7735-cd14-4381-89a8-f1129178e222} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.683287 [ 35659 ] {396bc6c9-18b6-4021-ac3b-568e3323d474} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3HexAreaM2(NULL, NULL);) 2025.06.18 11:21:13.687450 [ 35659 ] {396bc6c9-18b6-4021-ac3b-568e3323d474} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.704579 [ 35675 ] {59faa96f-c1f3-4e80-9538-9958e20aab93} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMillisecond();) 2025.06.18 11:21:13.708245 [ 35675 ] {59faa96f-c1f3-4e80-9538-9958e20aab93} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.729889 [ 35675 ] {5b4df064-bd80-4216-acb1-bd8f2dcffa0f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMinute();) 2025.06.18 11:21:13.733659 [ 35675 ] {5b4df064-bd80-4216-acb1-bd8f2dcffa0f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.757557 [ 35675 ] {ccde8fc9-89f9-4bc2-ae01-41088e45c294} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMonth();) 2025.06.18 11:21:13.761360 [ 35675 ] {ccde8fc9-89f9-4bc2-ae01-41088e45c294} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.783722 [ 35675 ] {2ecfe3a7-6282-43ed-b396-cb4fb9231522} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalNanosecond();) 2025.06.18 11:21:13.787364 [ 35675 ] {2ecfe3a7-6282-43ed-b396-cb4fb9231522} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.800067 [ 35673 ] {cedb1a75-0c7b-43e0-a734-450c31b490ab} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFD(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46226) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFD(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da2c2d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:13.802330 [ 35673 ] {cedb1a75-0c7b-43e0-a734-450c31b490ab} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFD(value). (CANNOT_NORMALIZE_STRING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da2c2d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:13.810113 [ 35675 ] {40d40bdd-ecbb-4bac-b20e-b5ff0dd9200b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalQuarter();) 2025.06.18 11:21:13.813685 [ 35675 ] {40d40bdd-ecbb-4bac-b20e-b5ff0dd9200b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.824460 [ 35659 ] {9ed359fe-e9fa-4145-b032-0626ec786c80} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3IsPentagon(NULL, NULL);) 2025.06.18 11:21:13.827997 [ 35659 ] {9ed359fe-e9fa-4145-b032-0626ec786c80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.835412 [ 35675 ] {3d4694e3-23e4-45a5-a40d-b36702f76bfe} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalSecond();) 2025.06.18 11:21:13.839175 [ 35675 ] {3d4694e3-23e4-45a5-a40d-b36702f76bfe} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.856327 [ 35659 ] {db645996-380e-4fd9-b714-5fb79d030ea3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3IsResClassIII(NULL, NULL);) 2025.06.18 11:21:13.859722 [ 35659 ] {db645996-380e-4fd9-b714-5fb79d030ea3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.861001 [ 35675 ] {8c803f55-e7c0-4481-a5b5-3ab9c423b023} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalWeek();) 2025.06.18 11:21:13.864474 [ 35675 ] {8c803f55-e7c0-4481-a5b5-3ab9c423b023} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.886178 [ 35675 ] {957ef275-a1f8-4bd0-b683-5d6122fe3ebb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalYear();) 2025.06.18 11:21:13.886320 [ 35659 ] {b774e254-9872-49f9-addb-66a6792ad7ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3IsValid(NULL, NULL);) 2025.06.18 11:21:13.889663 [ 35675 ] {957ef275-a1f8-4bd0-b683-5d6122fe3ebb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.889918 [ 35659 ] {b774e254-9872-49f9-addb-66a6792ad7ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.911508 [ 35675 ] {22b6c6cd-6d36-4cdd-add4-5d9d53d39f70} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 0, should be 1: In scope SELECT toJSONString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toJSONString();) 2025.06.18 11:21:13.914963 [ 35675 ] {22b6c6cd-6d36-4cdd-add4-5d9d53d39f70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 0, should be 1: In scope SELECT toJSONString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.937170 [ 35675 ] {181a9151-c7fe-4b71-99cd-009cb4354998} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toLastDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toLastDayOfMonth();) 2025.06.18 11:21:13.940835 [ 35675 ] {181a9151-c7fe-4b71-99cd-009cb4354998} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toLastDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.966581 [ 35675 ] {cc9ca3bc-945a-469a-a0bb-dd6feca5a350} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toLastDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toLastDayOfWeek();) 2025.06.18 11:21:13.970646 [ 35675 ] {cc9ca3bc-945a-469a-a0bb-dd6feca5a350} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toLastDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.972363 [ 35659 ] {ca180d19-ca4a-4952-97f8-26510020a18c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3NumHexagons(NULL, NULL);) 2025.06.18 11:21:13.975905 [ 35659 ] {ca180d19-ca4a-4952-97f8-26510020a18c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:13.994438 [ 35675 ] {2392c9d5-5790-443d-b7e0-35db016fd7c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 0, should be 1: In scope SELECT toLowCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toLowCardinality();) 2025.06.18 11:21:13.998127 [ 35675 ] {2392c9d5-5790-443d-b7e0-35db016fd7c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 0, should be 1: In scope SELECT toLowCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.005874 [ 35659 ] {0cdf3d0c-4c65-4e09-a3d5-d38d383f728f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3PointDistKm(NULL, NULL);) 2025.06.18 11:21:14.009696 [ 35659 ] {0cdf3d0c-4c65-4e09-a3d5-d38d383f728f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.021551 [ 35675 ] {4cc452d7-91aa-41d5-bc6e-bce2f70f9f02} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMillisecond();) 2025.06.18 11:21:14.025398 [ 35675 ] {4cc452d7-91aa-41d5-bc6e-bce2f70f9f02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.038361 [ 35659 ] {7fb3d944-0ecb-4548-b89c-888cbe40290d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3PointDistM(NULL, NULL);) 2025.06.18 11:21:14.041955 [ 35659 ] {7fb3d944-0ecb-4548-b89c-888cbe40290d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.048338 [ 35675 ] {4b41cc01-0aa4-48bf-a2f3-38c0654349ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMinute();) 2025.06.18 11:21:14.052274 [ 35675 ] {4b41cc01-0aa4-48bf-a2f3-38c0654349ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.070550 [ 35659 ] {2c032b64-03d1-40c1-88bb-70f399fba57d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3PointDistRads(NULL, NULL);) 2025.06.18 11:21:14.074148 [ 35659 ] {2c032b64-03d1-40c1-88bb-70f399fba57d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.079437 [ 35675 ] {6de02974-b85f-42aa-aeab-0c5dc15f0097} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toModifiedJulianDay();) 2025.06.18 11:21:14.083825 [ 35675 ] {6de02974-b85f-42aa-aeab-0c5dc15f0097} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.110419 [ 35675 ] {4f9a1dd6-5bfb-4144-9514-9d69bdc5fd1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toModifiedJulianDayOrNull();) 2025.06.18 11:21:14.114867 [ 35675 ] {4f9a1dd6-5bfb-4144-9514-9d69bdc5fd1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.138838 [ 35675 ] {1d874939-4feb-49ee-961f-33fb699c7c01} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonday(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMonday();) 2025.06.18 11:21:14.142677 [ 35675 ] {1d874939-4feb-49ee-961f-33fb699c7c01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonday(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.163833 [ 35047 ] {e504998d-8855-4b9d-8ed0-3b37221dfc19} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: -- `e + 1` is UInt16 SELECT DISTINCT t1.key, toUInt8(t1.id) as e FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND e + 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.166387 [ 35047 ] {e504998d-8855-4b9d-8ed0-3b37221dfc19} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.166967 [ 35675 ] {87f60035-c8e4-48ae-93f6-cbbf6754f009} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMonth();) 2025.06.18 11:21:14.170889 [ 35675 ] {87f60035-c8e4-48ae-93f6-cbbf6754f009} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.195639 [ 35675 ] {85bb9fdc-2768-4b3a-8697-e3dcf7483ee1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 0, should be 1: In scope SELECT toNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toNullable();) 2025.06.18 11:21:14.199367 [ 35675 ] {85bb9fdc-2768-4b3a-8697-e3dcf7483ee1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 0, should be 1: In scope SELECT toNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.211760 [ 35659 ] {71ea05bf-f948-4763-a928-5c2e6c6f0f9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ToGeo(NULL, NULL);) 2025.06.18 11:21:14.215806 [ 35659 ] {71ea05bf-f948-4763-a928-5c2e6c6f0f9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.225500 [ 35675 ] {8e69df0f-ae39-46ae-9d9c-88878e23aad5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toQuarter();) 2025.06.18 11:21:14.229194 [ 35675 ] {8e69df0f-ae39-46ae-9d9c-88878e23aad5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.243502 [ 35659 ] {be426f5e-8065-4673-bc5d-f7445ca8429f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ToGeoBoundary(NULL, NULL);) 2025.06.18 11:21:14.247107 [ 35659 ] {be426f5e-8065-4673-bc5d-f7445ca8429f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.253318 [ 35675 ] {821da8dc-acc8-4cc9-9f8a-7227795424fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeDayNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeDayNum();) 2025.06.18 11:21:14.257582 [ 35675 ] {821da8dc-acc8-4cc9-9f8a-7227795424fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeDayNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.282412 [ 35675 ] {79ccd069-803e-406e-a67a-538fa649ebda} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeHourNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeHourNum();) 2025.06.18 11:21:14.286560 [ 35675 ] {79ccd069-803e-406e-a67a-538fa649ebda} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeHourNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.310164 [ 35675 ] {09c6c934-b227-46bd-b8d6-0d3cd6193546} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMinuteNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeMinuteNum();) 2025.06.18 11:21:14.317238 [ 35675 ] {09c6c934-b227-46bd-b8d6-0d3cd6193546} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMinuteNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.343519 [ 35675 ] {f3fa887e-dc19-4fe3-87b1-5b753430580d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMonthNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeMonthNum();) 2025.06.18 11:21:14.347765 [ 35675 ] {f3fa887e-dc19-4fe3-87b1-5b753430580d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMonthNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.354384 [ 35659 ] {a4de264d-16a5-4467-95f7-f48c65c6dd99} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ToString(NULL, NULL);) 2025.06.18 11:21:14.357986 [ 35659 ] {a4de264d-16a5-4467-95f7-f48c65c6dd99} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.373567 [ 35675 ] {79d3a40b-0726-4f74-9766-8e2ed95c8554} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeQuarterNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeQuarterNum();) 2025.06.18 11:21:14.377774 [ 35675 ] {79d3a40b-0726-4f74-9766-8e2ed95c8554} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeQuarterNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.386931 [ 35659 ] {2809fbf7-58fd-4521-a74f-348cc62c93dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL);) 2025.06.18 11:21:14.390631 [ 35659 ] {2809fbf7-58fd-4521-a74f-348cc62c93dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.404301 [ 35675 ] {cc84f783-7f32-48c0-a973-38ebf32e6c78} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeSecondNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeSecondNum();) 2025.06.18 11:21:14.408723 [ 35675 ] {cc84f783-7f32-48c0-a973-38ebf32e6c78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeSecondNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.435540 [ 35675 ] {c31a1ecf-98e0-437b-9083-d21bfe0cd08d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeWeekNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeWeekNum();) 2025.06.18 11:21:14.440074 [ 35675 ] {c31a1ecf-98e0-437b-9083-d21bfe0cd08d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeWeekNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.477227 [ 35675 ] {54631dbc-b57f-484b-96b7-2dafc6883045} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeYearNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeYearNum();) 2025.06.18 11:21:14.481458 [ 35675 ] {54631dbc-b57f-484b-96b7-2dafc6883045} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeYearNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.502503 [ 35675 ] {e280a20d-6eb0-457a-ab75-3444059ceb88} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toSecond();) 2025.06.18 11:21:14.506596 [ 35675 ] {e280a20d-6eb0-457a-ab75-3444059ceb88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.527925 [ 35675 ] {e0c1399d-24a3-47b2-93ef-456af74887d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfDay();) 2025.06.18 11:21:14.531411 [ 35675 ] {e0c1399d-24a3-47b2-93ef-456af74887d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.532812 [ 35659 ] {0ab0eed3-1e44-42e3-a118-30521f2246bd} executeQuery: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT has(NULL, NULL);) 2025.06.18 11:21:14.535765 [ 35659 ] {0ab0eed3-1e44-42e3-a118-30521f2246bd} TCPHandler: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:14.555681 [ 35675 ] {caf00509-be23-41a1-a67d-dd57f7a8a41b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfFifteenMinutes();) 2025.06.18 11:21:14.559609 [ 35675 ] {caf00509-be23-41a1-a67d-dd57f7a8a41b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.582894 [ 35675 ] {8183693a-7dd9-4936-808b-60fa25076b57} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfFiveMinute();) 2025.06.18 11:21:14.587002 [ 35675 ] {8183693a-7dd9-4936-808b-60fa25076b57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.596356 [ 35673 ] {438f3fc3-e8db-4c4d-aba4-cd241cbab278} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKC(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46226) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFKC(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da5a0d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:14.598673 [ 35673 ] {438f3fc3-e8db-4c4d-aba4-cd241cbab278} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKC(value). (CANNOT_NORMALIZE_STRING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da5a0d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:14.610250 [ 35675 ] {ceab23dc-aa3d-45dc-8479-26f7040706b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfFiveMinutes();) 2025.06.18 11:21:14.613939 [ 35675 ] {ceab23dc-aa3d-45dc-8479-26f7040706b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.637847 [ 35675 ] {0f84915e-aa81-4343-9d6c-6bbacf525537} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfHour();) 2025.06.18 11:21:14.641775 [ 35675 ] {0f84915e-aa81-4343-9d6c-6bbacf525537} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.665943 [ 35675 ] {8d7103a7-85dc-480c-9da1-50a263727c33} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfISOYear();) 2025.06.18 11:21:14.669870 [ 35675 ] {8d7103a7-85dc-480c-9da1-50a263727c33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.694638 [ 35675 ] {381097bf-eba3-4802-a0f6-63e06ed068df} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, should be 2 or 3: In scope SELECT toStartOfInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfInterval();) 2025.06.18 11:21:14.696402 [ 35047 ] {94c019d9-c3c5-47cc-97b9-1df82b4a0235} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.698516 [ 35675 ] {381097bf-eba3-4802-a0f6-63e06ed068df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, should be 2 or 3: In scope SELECT toStartOfInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.698852 [ 35047 ] {94c019d9-c3c5-47cc-97b9-1df82b4a0235} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.721775 [ 35675 ] {58fb7980-1874-4666-9b98-d7021228700a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMicrosecond();) 2025.06.18 11:21:14.725743 [ 35675 ] {58fb7980-1874-4666-9b98-d7021228700a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.748635 [ 35675 ] {755e2421-2633-41bc-9a72-744cde55d8c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMillisecond();) 2025.06.18 11:21:14.752290 [ 35675 ] {755e2421-2633-41bc-9a72-744cde55d8c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.752442 [ 35047 ] {4c922a8d-f140-4f19-84a4-8bc134c0e055} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.754908 [ 35047 ] {4c922a8d-f140-4f19-84a4-8bc134c0e055} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.775580 [ 35675 ] {469d801a-b0e8-41b1-8d6e-537354e4156b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMinute();) 2025.06.18 11:21:14.779700 [ 35675 ] {469d801a-b0e8-41b1-8d6e-537354e4156b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.803741 [ 35675 ] {4d27d314-d085-450e-ad95-4af4c59b04bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMonth();) 2025.06.18 11:21:14.807657 [ 35675 ] {4d27d314-d085-450e-ad95-4af4c59b04bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.812224 [ 35047 ] {331b36eb-e529-44fb-b1c9-aac4def2e61d} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id + 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.814722 [ 35047 ] {331b36eb-e529-44fb-b1c9-aac4def2e61d} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb592d 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.831056 [ 35675 ] {3873c3a6-4059-45dc-b6d4-52249dc60ea7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfNanosecond();) 2025.06.18 11:21:14.834679 [ 35675 ] {3873c3a6-4059-45dc-b6d4-52249dc60ea7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.857944 [ 35675 ] {a2f1a4e8-7391-4c55-b869-d634034ffea8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfQuarter();) 2025.06.18 11:21:14.861866 [ 35675 ] {a2f1a4e8-7391-4c55-b869-d634034ffea8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.870573 [ 35047 ] {a0ce0646-69d1-4440-ba4f-6f4b26a67c63} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id + 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.873107 [ 35047 ] {a0ce0646-69d1-4440-ba4f-6f4b26a67c63} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034eb60df 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:413: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034eb5938 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c38ff8 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b814ec1 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be4b1ba 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be4eec4 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be47c02 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d85b39 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:14.884926 [ 35675 ] {6fb44301-bd76-4df1-bbb6-90295c57d547} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfSecond();) 2025.06.18 11:21:14.888560 [ 35675 ] {6fb44301-bd76-4df1-bbb6-90295c57d547} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.911049 [ 35675 ] {4465079a-8046-49d0-8135-432df5c49469} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfTenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfTenMinutes();) 2025.06.18 11:21:14.914957 [ 35675 ] {4465079a-8046-49d0-8135-432df5c49469} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfTenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.915844 [ 35047 ] {0ddc74b2-8952-4f15-a2a4-d56e388e8176} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:14.919235 [ 35047 ] {0ddc74b2-8952-4f15-a2a4-d56e388e8176} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:14.938274 [ 35675 ] {ccbcfe98-039d-48ca-958f-fb3be7cd3a43} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toStartOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfWeek();) 2025.06.18 11:21:14.942041 [ 35675 ] {ccbcfe98-039d-48ca-958f-fb3be7cd3a43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toStartOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.962337 [ 35047 ] {16535097-7ad3-40d6-8db3-95854704b59b} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:14.965263 [ 35047 ] {16535097-7ad3-40d6-8db3-95854704b59b} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000083f3cd7 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a9bf12e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334eb606 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:21:14.968556 [ 35675 ] {f0cee901-5537-4bd8-ab0a-5a08c2442ab8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfYear();) 2025.06.18 11:21:14.972369 [ 35675 ] {f0cee901-5537-4bd8-ab0a-5a08c2442ab8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.991947 [ 35659 ] {6ab35b7f-ab11-47b9-8f3b-6e2ec44af43b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hasThreadFuzzer(NULL, NULL);) 2025.06.18 11:21:14.991947 [ 35675 ] {e1067f35-deca-47a7-b00f-3cca3ade3328} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 0 arguments: In scope SELECT toString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toString();) 2025.06.18 11:21:14.995530 [ 35675 ] {e1067f35-deca-47a7-b00f-3cca3ade3328} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 0 arguments: In scope SELECT toString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:14.995530 [ 35659 ] {6ab35b7f-ab11-47b9-8f3b-6e2ec44af43b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.019329 [ 35675 ] {70f8e34f-5d1c-438e-951b-18945b3d29df} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 0, should be 1: In scope SELECT toStringCutToZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStringCutToZero();) 2025.06.18 11:21:15.023046 [ 35675 ] {70f8e34f-5d1c-438e-951b-18945b3d29df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 0, should be 1: In scope SELECT toStringCutToZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.037546 [ 35047 ] {72e45e00-3463-427c-bca1-adb00badb6b6} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t2.key = t2.key2) AND ((t1.id = t2.id) OR (t2.key2 IS NULL)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 JOIN t2_nullable as t2 ON t2.key == t2.key2 AND (t1.id == t2.id OR isNull(t2.key2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.041272 [ 35047 ] {72e45e00-3463-427c-bca1-adb00badb6b6} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t2.key = t2.key2) AND ((t1.id = t2.id) OR (t2.key2 IS NULL)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.049510 [ 35675 ] {04e4d329-5666-4f2f-8fb2-5a069b920185} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 0, should be 1 or 2: In scope SELECT toTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTime();) 2025.06.18 11:21:15.053374 [ 35675 ] {04e4d329-5666-4f2f-8fb2-5a069b920185} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 0, should be 1 or 2: In scope SELECT toTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.075938 [ 35675 ] {31726dbd-9fe0-4b5f-a2c5-49c48f25fe95} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimeZone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTimeZone();) 2025.06.18 11:21:15.079631 [ 35675 ] {31726dbd-9fe0-4b5f-a2c5-49c48f25fe95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimeZone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.103005 [ 35675 ] {0effadd3-047f-4aed-acfb-007fb512d620} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimezone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTimezone();) 2025.06.18 11:21:15.105827 [ 35047 ] {7df61889-5aa4-4639-86a8-56c8144eb615} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON (t2.key = t2.key2) OR (t1.id = t2.id). (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 JOIN t2 ON t2.key == t2.key2 OR t1.id == t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.106804 [ 35675 ] {0effadd3-047f-4aed-acfb-007fb512d620} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimezone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.108694 [ 35047 ] {7df61889-5aa4-4639-86a8-56c8144eb615} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in INNER JOIN ... ON (t2.key = t2.key2) OR (t1.id = t2.id). (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.133383 [ 35675 ] {71b62546-d59c-446b-881a-f5c519faeef2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 0, should be 1: In scope SELECT toTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTypeName();) 2025.06.18 11:21:15.138492 [ 35675 ] {71b62546-d59c-446b-881a-f5c519faeef2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 0, should be 1: In scope SELECT toTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.165340 [ 35675 ] {16fce58c-49c7-4faf-8f85-40d4f4bcf32d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128();) 2025.06.18 11:21:15.170069 [ 35675 ] {16fce58c-49c7-4faf-8f85-40d4f4bcf32d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.185079 [ 35047 ] {084197f4-5004-4ac2-bbee-d97666ea1ea4} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t2.key = t2.key2) AND (((t1.key = t1.key2) AND (t1.key != 'XXX')) OR (t1.id = t2.id))) AND (t1.id = t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 JOIN t2 ON (t2.key == t2.key2 AND (t1.key == t1.key2 AND t1.key != 'XXX' OR t1.id == t2.id)) AND t1.id == t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.187762 [ 35047 ] {084197f4-5004-4ac2-bbee-d97666ea1ea4} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t2.key = t2.key2) AND (((t1.key = t1.key2) AND (t1.key != 'XXX')) OR (t1.id = t2.id))) AND (t1.id = t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 8. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.197831 [ 35675 ] {ec8339b8-0316-4eff-8ef6-22ce0d06e9b2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128OrDefault();) 2025.06.18 11:21:15.202297 [ 35675 ] {ec8339b8-0316-4eff-8ef6-22ce0d06e9b2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.229586 [ 35675 ] {d7cea075-4784-4588-8771-02cbe608ddb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128OrNull();) 2025.06.18 11:21:15.234056 [ 35675 ] {d7cea075-4784-4588-8771-02cbe608ddb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.234381 [ 35659 ] {43bd4849-b2d0-4ec3-878a-c8ba1f07ef13} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hex(NULL, NULL);) 2025.06.18 11:21:15.238096 [ 35659 ] {43bd4849-b2d0-4ec3-878a-c8ba1f07ef13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.260690 [ 35675 ] {888064b9-599d-4117-8f88-4a267b826e52} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128OrZero();) 2025.06.18 11:21:15.264550 [ 35675 ] {888064b9-599d-4117-8f88-4a267b826e52} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.288983 [ 35675 ] {bda28f00-a90c-420b-bf84-ed141898e977} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16();) 2025.06.18 11:21:15.292927 [ 35675 ] {bda28f00-a90c-420b-bf84-ed141898e977} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.314254 [ 35675 ] {4a9982fe-2591-44cd-b6c9-5e946ad597d3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16OrDefault();) 2025.06.18 11:21:15.317845 [ 35675 ] {4a9982fe-2591-44cd-b6c9-5e946ad597d3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.341464 [ 35675 ] {a39e10f5-1a8c-48e2-86b7-860571f4542c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16OrNull();) 2025.06.18 11:21:15.345251 [ 35675 ] {a39e10f5-1a8c-48e2-86b7-860571f4542c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.367773 [ 35675 ] {7d95b75e-7ff4-4bc6-a5f2-a77eb023c10e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16OrZero();) 2025.06.18 11:21:15.371523 [ 35675 ] {7d95b75e-7ff4-4bc6-a5f2-a77eb023c10e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.380382 [ 35047 ] {3b8007fe-c481-4852-9d4b-b2f541f8f85f} executeQuery: Code: 403. DB::Exception: JOIN ALL INNER JOIN ... ON (t1.id = t2.id) AND (t1.id >= t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: -- non-equi condition containing columns from different tables doesn't supported yet SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id >= t2.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.383006 [ 35047 ] {3b8007fe-c481-4852-9d4b-b2f541f8f85f} TCPHandler: Code: 403. DB::Exception: JOIN ALL INNER JOIN ... ON (t1.id = t2.id) AND (t1.id >= t2.id) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.394395 [ 35675 ] {b4427332-7ff7-4d16-bc8f-f3dc1623426f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256();) 2025.06.18 11:21:15.398038 [ 35675 ] {b4427332-7ff7-4d16-bc8f-f3dc1623426f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.399874 [ 35673 ] {58d01724-8ca9-467b-8aed-fe034ff14770} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKD(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46226) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFKD(value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da87ed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:15.402004 [ 35673 ] {58d01724-8ca9-467b-8aed-fe034ff14770} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKD(value). (CANNOT_NORMALIZE_STRING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da87ed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:21:15.422415 [ 35675 ] {d00bd9a8-70fa-42c2-ba94-00a109bbfd80} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256OrDefault();) 2025.06.18 11:21:15.426133 [ 35675 ] {d00bd9a8-70fa-42c2-ba94-00a109bbfd80} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.449171 [ 35675 ] {40e306bc-3307-4bb1-bdfb-9c177666e26b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256OrNull();) 2025.06.18 11:21:15.451639 [ 35047 ] {fda9da34-1bb7-4226-b565-0df5f9f4ffd2} executeQuery: Code: 403. DB::Exception: JOIN ANY INNER JOIN ... ON (t1.id = t2.id) AND (t2.key = t2.key2) AND (t1.key = t1.key2) AND (t1.id >= length(t2.key)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT * FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND t1.id >= length(t2.key);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.452778 [ 35675 ] {40e306bc-3307-4bb1-bdfb-9c177666e26b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.454374 [ 35047 ] {fda9da34-1bb7-4226-b565-0df5f9f4ffd2} TCPHandler: Code: 403. DB::Exception: JOIN ANY INNER JOIN ... ON (t1.id = t2.id) AND (t2.key = t2.key2) AND (t1.key = t1.key2) AND (t1.id >= length(t2.key)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.474109 [ 35675 ] {099ec630-8d0c-46c3-bc12-ac11b8f1ebc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256OrZero();) 2025.06.18 11:21:15.477534 [ 35675 ] {099ec630-8d0c-46c3-bc12-ac11b8f1ebc1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.500382 [ 35675 ] {598d23da-8ed1-4616-847e-49a1323f7d07} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32();) 2025.06.18 11:21:15.504006 [ 35675 ] {598d23da-8ed1-4616-847e-49a1323f7d07} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.528205 [ 35675 ] {7ca0e4d6-9b4a-41f4-8654-41efd3ff3afa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32OrDefault();) 2025.06.18 11:21:15.532394 [ 35675 ] {7ca0e4d6-9b4a-41f4-8654-41efd3ff3afa} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.555564 [ 35675 ] {08c881e7-08df-4979-816a-774287ab7856} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32OrNull();) 2025.06.18 11:21:15.559345 [ 35675 ] {08c881e7-08df-4979-816a-774287ab7856} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.583274 [ 35675 ] {f66d5369-6581-47cb-863c-c274d4157aad} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32OrZero();) 2025.06.18 11:21:15.587108 [ 35675 ] {f66d5369-6581-47cb-863c-c274d4157aad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.611691 [ 35675 ] {d862baeb-268e-4465-9be2-c704b7a440af} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64();) 2025.06.18 11:21:15.615485 [ 35675 ] {d862baeb-268e-4465-9be2-c704b7a440af} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.638929 [ 35675 ] {44fff649-3cfc-44b2-b6c1-32ff6c0b3b43} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64OrDefault();) 2025.06.18 11:21:15.642824 [ 35675 ] {44fff649-3cfc-44b2-b6c1-32ff6c0b3b43} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.645885 [ 35659 ] {0086969c-c2ae-45e6-aef9-5650e7df284c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hostName(NULL, NULL);) 2025.06.18 11:21:15.650169 [ 35659 ] {0086969c-c2ae-45e6-aef9-5650e7df284c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.667669 [ 35675 ] {55409f4d-4e9b-45b9-bd87-e701deea3e87} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64OrNull();) 2025.06.18 11:21:15.671466 [ 35675 ] {55409f4d-4e9b-45b9-bd87-e701deea3e87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.678146 [ 35659 ] {1ab31ead-e988-438e-882f-7c28f34fce43} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hostname(NULL, NULL);) 2025.06.18 11:21:15.681679 [ 35659 ] {1ab31ead-e988-438e-882f-7c28f34fce43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.688809 [ 35047 ] {65ae64f0-34b4-499b-a70d-0e74861a442a} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t22.key = t22.key2) OR (t1.id = t22.id)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON t1.id == t22.idd and (t22.key == t22.key2 OR t1.id == t22.id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.691342 [ 35047 ] {65ae64f0-34b4-499b-a70d-0e74861a442a} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t22.key = t22.key2) OR (t1.id = t22.id)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.695031 [ 35675 ] {ee6f6750-473d-42dc-a253-6a5b51fda985} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64OrZero();) 2025.06.18 11:21:15.698685 [ 35675 ] {ee6f6750-473d-42dc-a253-6a5b51fda985} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.722308 [ 35675 ] {5a86a4ef-8143-4037-b181-b72b328f0e0a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8();) 2025.06.18 11:21:15.726418 [ 35675 ] {5a86a4ef-8143-4037-b181-b72b328f0e0a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.750394 [ 35675 ] {2abcff60-9196-488b-b388-2eb5b4f07f48} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8OrDefault();) 2025.06.18 11:21:15.754238 [ 35675 ] {2abcff60-9196-488b-b388-2eb5b4f07f48} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.755140 [ 35047 ] {72eaff96-d06b-4b3d-830a-f5aecdb71c72} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t1.id = t22.id) OR (t22.key = t22.key2)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON t1.id == t22.idd and (t1.id == t22.id OR t22.key == t22.key2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.756082 [ 35659 ] {f16bd714-7b0f-4be7-a679-9b838cd15444} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT identity(NULL, NULL);) 2025.06.18 11:21:15.757704 [ 35047 ] {72eaff96-d06b-4b3d-830a-f5aecdb71c72} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON (t1.id = t22.idd) AND ((t1.id = t22.id) OR (t22.key = t22.key2)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.759615 [ 35659 ] {f16bd714-7b0f-4be7-a679-9b838cd15444} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.777184 [ 35675 ] {27d431a0-06de-44b2-a44b-f5435810b57c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8OrNull();) 2025.06.18 11:21:15.781086 [ 35675 ] {27d431a0-06de-44b2-a44b-f5435810b57c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.787435 [ 35659 ] {7b8e6d2e-8ba6-4950-9168-5927a978b226} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT idnaDecode(NULL, NULL);) 2025.06.18 11:21:15.790943 [ 35659 ] {7b8e6d2e-8ba6-4950-9168-5927a978b226} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.804607 [ 35675 ] {8a717212-d6c1-4084-88cd-3b2352472a1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8OrZero();) 2025.06.18 11:21:15.808694 [ 35675 ] {8a717212-d6c1-4084-88cd-3b2352472a1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.816027 [ 35659 ] {4a19c380-e6f6-498a-83d2-94a09b43f786} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT idnaEncode(NULL, NULL);) 2025.06.18 11:21:15.818948 [ 35047 ] {6fe2a7c5-dca3-49de-8d51-959a077a8d89} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t22.key = t22.key2) OR (t1.id = t22.id)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON (t22.key == t22.key2 OR t1.id == t22.id) and t1.id == t22.idd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.819543 [ 35659 ] {4a19c380-e6f6-498a-83d2-94a09b43f786} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.821517 [ 35047 ] {6fe2a7c5-dca3-49de-8d51-959a077a8d89} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t22.key = t22.key2) OR (t1.id = t22.id)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.832079 [ 35675 ] {8b9e2086-3192-4959-ac19-217f3c0183ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT toUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUTCTimestamp();) 2025.06.18 11:21:15.835813 [ 35675 ] {8b9e2086-3192-4959-ac19-217f3c0183ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT toUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.847108 [ 35659 ] {991bb845-4449-4911-a235-8cf10ccb41df} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT if(NULL, NULL);) 2025.06.18 11:21:15.850554 [ 35659 ] {991bb845-4449-4911-a235-8cf10ccb41df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.858883 [ 35675 ] {b0ff55dd-3251-4faf-8f61-ed3ef5b7a6d8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 0 arguments: In scope SELECT toUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUID();) 2025.06.18 11:21:15.862675 [ 35675 ] {b0ff55dd-3251-4faf-8f61-ed3ef5b7a6d8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 0 arguments: In scope SELECT toUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.882363 [ 35047 ] {2995fed6-0537-4818-bef3-a72c5a481227} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON (t1.id == t22.id OR t22.key == t22.key2) and t1.id == t22.idd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.884992 [ 35047 ] {2995fed6-0537-4818-bef3-a72c5a481227} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND (t1.id = t22.idd) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:15.890321 [ 35675 ] {b9ed5833-bf22-4f40-ae73-dfd06a64f28b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUIDOrDefault();) 2025.06.18 11:21:15.894848 [ 35675 ] {b9ed5833-bf22-4f40-ae73-dfd06a64f28b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.919191 [ 35675 ] {888f719c-44e5-43b0-a515-a8fa3c7c0e3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUIDOrNull();) 2025.06.18 11:21:15.923298 [ 35675 ] {888f719c-44e5-43b0-a515-a8fa3c7c0e3b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.947612 [ 35675 ] {bfb3e478-a58f-4739-9964-8c6ec5cc62c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUIDOrZero();) 2025.06.18 11:21:15.951882 [ 35675 ] {bfb3e478-a58f-4739-9964-8c6ec5cc62c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:15.976508 [ 35675 ] {f46774f7-f22e-4b5a-934b-82337e89f712} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp();) 2025.06.18 11:21:15.980462 [ 35675 ] {f46774f7-f22e-4b5a-934b-82337e89f712} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.001003 [ 35047 ] {8dae6f71-5b85-4561-9fff-66daf77fa67c} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND ((t1.id = t22.idd) AND ((t1.key2 = 'a1') OR (t1.key2 = 'a2') OR (t1.key2 = 'a3') OR (t1.key2 = 'a4') OR (t1.key2 = 'a5') OR (t1.key2 = 'a6') OR (t1.key2 = 'a7') OR (t1.key2 = 'a8') OR (t1.key2 = 'a9') OR (t1.key2 = 'a10') OR (t1.key2 = 'a11') OR (t1.key2 = 'a12') OR (t1.key2 = 'a13') OR (t1.key2 = 'a14') OR (t1.key2 = 'a15') OR (t1.key2 = 'a16') OR (t1.key2 = 'a17') OR (t1.key2 = 'a18') OR (t1.key2 = 'a19') OR (t1.key2 = '111'))) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45948) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: SELECT 't22', * FROM t1 JOIN t22 ON (t1.id == t22.id OR t22.key == t22.key2) and (t1.id == t22.idd AND (t1.key2 = 'a1' OR t1.key2 = 'a2' OR t1.key2 = 'a3' OR t1.key2 = 'a4' OR t1.key2 = 'a5' OR t1.key2 = 'a6' OR t1.key2 = 'a7' OR t1.key2 = 'a8' OR t1.key2 = 'a9' OR t1.key2 = 'a10' OR t1.key2 = 'a11' OR t1.key2 = 'a12' OR t1.key2 = 'a13' OR t1.key2 = 'a14' OR t1.key2 = 'a15' OR t1.key2 = 'a16' OR t1.key2 = 'a17' OR t1.key2 = 'a18' OR t1.key2 = 'a19' OR t1.key2 = '111'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:16.003962 [ 35675 ] {9043f507-2807-46a2-b73f-83a29a9d8b57} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp64Micro();) 2025.06.18 11:21:16.028338 [ 35047 ] {8dae6f71-5b85-4561-9fff-66daf77fa67c} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.id = t22.id) OR (t22.key = t22.key2)) AND ((t1.id = t22.idd) AND ((t1.key2 = 'a1') OR (t1.key2 = 'a2') OR (t1.key2 = 'a3') OR (t1.key2 = 'a4') OR (t1.key2 = 'a5') OR (t1.key2 = 'a6') OR (t1.key2 = 'a7') OR (t1.key2 = 'a8') OR (t1.key2 = 'a9') OR (t1.key2 = 'a10') OR (t1.key2 = 'a11') OR (t1.key2 = 'a12') OR (t1.key2 = 'a13') OR (t1.key2 = 'a14') OR (t1.key2 = 'a15') OR (t1.key2 = 'a16') OR (t1.key2 = 'a17') OR (t1.key2 = 'a18') OR (t1.key2 = 'a19') OR (t1.key2 = '111'))) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddfa81 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x0000000034ddd7cb 6. ./contrib/llvm-project/libcxx/include/vector:553: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dcaa0e 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 9. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:16.029674 [ 35675 ] {9043f507-2807-46a2-b73f-83a29a9d8b57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.053060 [ 35675 ] {37f356ae-59e7-43f3-b2c9-5807d6780b5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp64Milli();) 2025.06.18 11:21:16.056976 [ 35675 ] {37f356ae-59e7-43f3-b2c9-5807d6780b5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.080574 [ 35675 ] {fad367e7-267e-4b8f-bccd-7cfb4628f0dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp64Nano();) 2025.06.18 11:21:16.084380 [ 35675 ] {fad367e7-267e-4b8f-bccd-7cfb4628f0dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.107147 [ 35675 ] {66f0d956-61a3-44d6-bf9b-3e22fefe2978} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT toValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toValidUTF8();) 2025.06.18 11:21:16.110826 [ 35675 ] {66f0d956-61a3-44d6-bf9b-3e22fefe2978} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT toValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.134051 [ 35675 ] {4595d748-094d-4792-936d-326b7f103a69} executeQuery: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toWeek();) 2025.06.18 11:21:16.137702 [ 35675 ] {4595d748-094d-4792-936d-326b7f103a69} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.160896 [ 35675 ] {d44f6978-1b98-408a-a1c6-39cabb2ac163} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYYYYMM();) 2025.06.18 11:21:16.164562 [ 35675 ] {d44f6978-1b98-408a-a1c6-39cabb2ac163} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.186731 [ 35675 ] {4d2d0d94-da63-4ac6-9224-2cd3a194d3e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYYYYMMDD();) 2025.06.18 11:21:16.190366 [ 35675 ] {4d2d0d94-da63-4ac6-9224-2cd3a194d3e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.212811 [ 35675 ] {1a8d2e9a-f70e-40f2-b167-e7f9b4a14834} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYYYYMMDDhhmmss();) 2025.06.18 11:21:16.216482 [ 35675 ] {1a8d2e9a-f70e-40f2-b167-e7f9b4a14834} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.239936 [ 35675 ] {778c79ce-77d4-42f5-ae7f-9684735a254d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYear();) 2025.06.18 11:21:16.243636 [ 35675 ] {778c79ce-77d4-42f5-ae7f-9684735a254d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.265814 [ 35659 ] {263ea95e-36a9-45af-8238-411d4a315b0a} executeQuery: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT indexOf(NULL, NULL);) 2025.06.18 11:21:16.267424 [ 35675 ] {c152e47a-921b-42fd-90c7-e4819a44c543} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toYearWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYearWeek();) 2025.06.18 11:21:16.269749 [ 35659 ] {263ea95e-36a9-45af-8238-411d4a315b0a} TCPHandler: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:16.271339 [ 35675 ] {c152e47a-921b-42fd-90c7-e4819a44c543} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toYearWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.294701 [ 35675 ] {a4a74119-f04a-43bb-be85-92ceacbffb8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT to_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT to_utc_timestamp();) 2025.06.18 11:21:16.298549 [ 35659 ] {8792738b-c4ca-4580-bb2f-680b02b07ecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initcap(NULL, NULL);) 2025.06.18 11:21:16.298633 [ 35675 ] {a4a74119-f04a-43bb-be85-92ceacbffb8a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT to_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.302192 [ 35659 ] {8792738b-c4ca-4580-bb2f-680b02b07ecb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.327682 [ 35659 ] {f896991a-aae9-4a72-b3ed-274aa8d67308} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initcapUTF8(NULL, NULL);) 2025.06.18 11:21:16.331220 [ 35659 ] {f896991a-aae9-4a72-b3ed-274aa8d67308} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.358614 [ 35659 ] {638aba19-32a3-4c35-80b3-5a3278eb82c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initialQueryID(NULL, NULL);) 2025.06.18 11:21:16.362231 [ 35659 ] {638aba19-32a3-4c35-80b3-5a3278eb82c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.370221 [ 35675 ] {da1d72fe-a840-49e4-9e2e-b0440bc9f88b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 0, should be 1: In scope SELECT tokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tokens();) 2025.06.18 11:21:16.374354 [ 35675 ] {da1d72fe-a840-49e4-9e2e-b0440bc9f88b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 0, should be 1: In scope SELECT tokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.389810 [ 35659 ] {93f472d1-26db-407e-9b15-28f6294d4c82} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initial_query_id(NULL, NULL);) 2025.06.18 11:21:16.393873 [ 35659 ] {93f472d1-26db-407e-9b15-28f6294d4c82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.399279 [ 35675 ] {79f65236-fde4-42a8-a5b9-a25709a16051} executeQuery: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topK();) 2025.06.18 11:21:16.403085 [ 35675 ] {79f65236-fde4-42a8-a5b9-a25709a16051} TCPHandler: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.422854 [ 35659 ] {de41578a-2be7-4939-8ca5-023ae0ad1b49} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initializeAggregation(NULL, NULL);) 2025.06.18 11:21:16.426246 [ 35675 ] {4612112b-9df2-4660-88cb-9c59b6388267} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topKWeighted();) 2025.06.18 11:21:16.426601 [ 35659 ] {de41578a-2be7-4939-8ca5-023ae0ad1b49} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:16.429970 [ 35675 ] {4612112b-9df2-4660-88cb-9c59b6388267} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.454082 [ 35675 ] {41e6233d-ccae-41ab-aad9-46b93f3e4626} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 0, should be 1: In scope SELECT topLevelDomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topLevelDomain();) 2025.06.18 11:21:16.458117 [ 35675 ] {41e6233d-ccae-41ab-aad9-46b93f3e4626} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 0, should be 1: In scope SELECT topLevelDomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.481365 [ 35675 ] {b3c22c1d-07ce-41c2-8ee8-2bef12681720} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 0, should be 1: In scope SELECT topLevelDomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topLevelDomainRFC();) 2025.06.18 11:21:16.485182 [ 35675 ] {b3c22c1d-07ce-41c2-8ee8-2bef12681720} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 0, should be 1: In scope SELECT topLevelDomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.605242 [ 35659 ] {d46ae429-db4b-4c0b-b28a-59a9c63b1c42} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intExp10(NULL, NULL);) 2025.06.18 11:21:16.608772 [ 35659 ] {d46ae429-db4b-4c0b-b28a-59a9c63b1c42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.638160 [ 35659 ] {b3f4516b-e020-47b7-91ed-b5d061a89478} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intExp2(NULL, NULL);) 2025.06.18 11:21:16.641639 [ 35659 ] {b3f4516b-e020-47b7-91ed-b5d061a89478} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.666594 [ 35659 ] {67f592fc-b603-492f-8107-1302d20303e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intHash32(NULL, NULL);) 2025.06.18 11:21:16.670136 [ 35659 ] {67f592fc-b603-492f-8107-1302d20303e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.672859 [ 35675 ] {991ed230-f602-4fed-af3e-641e64bb6d15} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 0, should be 3 or 4: In scope SELECT transform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT transform();) 2025.06.18 11:21:16.678041 [ 35675 ] {991ed230-f602-4fed-af3e-641e64bb6d15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 0, should be 3 or 4: In scope SELECT transform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.696378 [ 35659 ] {c8385956-1014-4857-ba43-f76c7d9f7f90} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intHash64(NULL, NULL);) 2025.06.18 11:21:16.700423 [ 35659 ] {c8385956-1014-4857-ba43-f76c7d9f7f90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.707324 [ 35675 ] {d4f80799-5e64-42b9-8b53-3dda87e7f334} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 0, should be 3: In scope SELECT translate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT translate();) 2025.06.18 11:21:16.711862 [ 35675 ] {d4f80799-5e64-42b9-8b53-3dda87e7f334} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 0, should be 3: In scope SELECT translate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.738462 [ 35675 ] {c1a49ca4-dc59-4de2-b881-9bf18c927208} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 0, should be 3: In scope SELECT translateUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT translateUTF8();) 2025.06.18 11:21:16.742850 [ 35675 ] {c1a49ca4-dc59-4de2-b881-9bf18c927208} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 0, should be 3: In scope SELECT translateUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.769864 [ 35675 ] {6b455807-43b8-4432-b93e-8333d7bdbd34} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 0, should be 1: In scope SELECT trimBoth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trimBoth();) 2025.06.18 11:21:16.774164 [ 35675 ] {6b455807-43b8-4432-b93e-8333d7bdbd34} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 0, should be 1: In scope SELECT trimBoth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.791500 [ 35659 ] {f429000a-7096-4563-90b8-9ec1f1be9b24} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isConstant(NULL, NULL);) 2025.06.18 11:21:16.794839 [ 35659 ] {f429000a-7096-4563-90b8-9ec1f1be9b24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.801587 [ 35675 ] {95d2f3a8-b2c9-44fb-9456-debfd2b0df5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 0, should be 1: In scope SELECT trimLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trimLeft();) 2025.06.18 11:21:16.805907 [ 35675 ] {95d2f3a8-b2c9-44fb-9456-debfd2b0df5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 0, should be 1: In scope SELECT trimLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.827105 [ 35675 ] {de4ea247-95e7-433d-8448-2d26bc4c203a} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 0, should be 1: In scope SELECT trimRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trimRight();) 2025.06.18 11:21:16.830936 [ 35675 ] {de4ea247-95e7-433d-8448-2d26bc4c203a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 0, should be 1: In scope SELECT trimRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.858610 [ 35675 ] {98a5595b-09ac-4528-a93a-6666acc251b3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trunc();) 2025.06.18 11:21:16.862602 [ 35675 ] {98a5595b-09ac-4528-a93a-6666acc251b3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.883558 [ 35659 ] {0dbbb3b0-e363-4c63-b975-063e066bffd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isDynamicElementInSharedData(NULL, NULL);) 2025.06.18 11:21:16.886564 [ 35675 ] {417d84fa-6fb4-4d58-9480-c3435aca2c21} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT truncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT truncate();) 2025.06.18 11:21:16.887664 [ 35659 ] {0dbbb3b0-e363-4c63-b975-063e066bffd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.890246 [ 35675 ] {417d84fa-6fb4-4d58-9480-c3435aca2c21} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT truncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.912922 [ 35675 ] {7224f957-fa86-4195-ab7c-70e187876217} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryBase58Decode();) 2025.06.18 11:21:16.916314 [ 35675 ] {7224f957-fa86-4195-ab7c-70e187876217} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.918690 [ 35659 ] {04b4c135-b929-4dbd-8d10-df84e7065651} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isFinite(NULL, NULL);) 2025.06.18 11:21:16.922396 [ 35659 ] {04b4c135-b929-4dbd-8d10-df84e7065651} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.937561 [ 35675 ] {f6674caa-cddf-4c09-acb0-5b5b6c5f2114} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryBase64Decode();) 2025.06.18 11:21:16.940951 [ 35675 ] {f6674caa-cddf-4c09-acb0-5b5b6c5f2114} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.951146 [ 35659 ] {47ef4c16-5b7e-45bc-b764-fff85c4564a4} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isIPAddressInRange(NULL, NULL);) 2025.06.18 11:21:16.954740 [ 35659 ] {47ef4c16-5b7e-45bc-b764-fff85c4564a4} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:16.962126 [ 35675 ] {437b005b-82dc-44fe-9701-f2cd44a7d90d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryBase64URLDecode();) 2025.06.18 11:21:16.965931 [ 35675 ] {437b005b-82dc-44fe-9701-f2cd44a7d90d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.983610 [ 35659 ] {a8b3e16e-7cc9-4e86-926b-9c69febc55eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isIPv4String(NULL, NULL);) 2025.06.18 11:21:16.987393 [ 35659 ] {a8b3e16e-7cc9-4e86-926b-9c69febc55eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:16.987949 [ 35675 ] {e5389b7d-4886-4a21-95bc-092548c8ae07} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT tryDecrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryDecrypt();) 2025.06.18 11:21:16.991551 [ 35675 ] {e5389b7d-4886-4a21-95bc-092548c8ae07} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT tryDecrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.013795 [ 35675 ] {cd82c011-f959-4465-a9b9-a5a2820b2782} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 0, should be 1: In scope SELECT tryIdnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryIdnaEncode();) 2025.06.18 11:21:17.017355 [ 35659 ] {3ce8050f-0f2d-4a88-8400-7145d60f20f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isIPv6String(NULL, NULL);) 2025.06.18 11:21:17.017382 [ 35675 ] {cd82c011-f959-4465-a9b9-a5a2820b2782} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 0, should be 1: In scope SELECT tryIdnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.021551 [ 35659 ] {3ce8050f-0f2d-4a88-8400-7145d60f20f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.039765 [ 35675 ] {4925de04-c702-4fbe-80c0-e8d3e4cca768} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryPunycodeDecode();) 2025.06.18 11:21:17.043622 [ 35675 ] {4925de04-c702-4fbe-80c0-e8d3e4cca768} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.051285 [ 35659 ] {f676a830-0dd4-4af2-a176-5ea354a1c31f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isInfinite(NULL, NULL);) 2025.06.18 11:21:17.055345 [ 35659 ] {f676a830-0dd4-4af2-a176-5ea354a1c31f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.066699 [ 35675 ] {5405f6dc-ba34-4473-b1e0-4aa1c85cbab0} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 0, should be 2 or 3: In scope SELECT tumble(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tumble();) 2025.06.18 11:21:17.070674 [ 35675 ] {5405f6dc-ba34-4473-b1e0-4aa1c85cbab0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 0, should be 2 or 3: In scope SELECT tumble(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.084929 [ 35659 ] {bd337aa1-f622-4cc7-8117-65ace9ffbea2} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNaN(NULL, NULL);) 2025.06.18 11:21:17.088757 [ 35659 ] {bd337aa1-f622-4cc7-8117-65ace9ffbea2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.092698 [ 35675 ] {1948d756-0ed4-4218-9cc1-3fe2502762c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumbleEnd doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tumbleEnd();) 2025.06.18 11:21:17.096244 [ 35675 ] {1948d756-0ed4-4218-9cc1-3fe2502762c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumbleEnd doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.117679 [ 35659 ] {2868ec7a-decf-46a8-8555-255829fb6d79} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNotDistinctFrom(NULL, NULL);) 2025.06.18 11:21:17.118246 [ 35675 ] {66943444-e04e-45f0-a555-1d95d0ec9c5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumbleStart doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tumbleStart();) 2025.06.18 11:21:17.121706 [ 35675 ] {66943444-e04e-45f0-a555-1d95d0ec9c5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumbleStart doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.122065 [ 35659 ] {2868ec7a-decf-46a8-8555-255829fb6d79} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) 2025.06.18 11:21:17.154034 [ 35659 ] {431c292a-020c-4000-903b-fbedb0f10884} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNotNull(NULL, NULL);) 2025.06.18 11:21:17.157984 [ 35659 ] {431c292a-020c-4000-903b-fbedb0f10884} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.189745 [ 35659 ] {46a0b7b4-bba9-4168-af7a-c30dbf88bd80} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNull(NULL, NULL);) 2025.06.18 11:21:17.193974 [ 35659 ] {46a0b7b4-bba9-4168-af7a-c30dbf88bd80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.202132 [ 35675 ] {b0d784ca-6ff7-40a8-80dc-35a46ec7c1b9} executeQuery: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleConcat();) 2025.06.18 11:21:17.206637 [ 35675 ] {b0d784ca-6ff7-40a8-80dc-35a46ec7c1b9} TCPHandler: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.222972 [ 35659 ] {7428e26e-e93c-4a02-b711-95719e16c9d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNullable(NULL, NULL);) 2025.06.18 11:21:17.226717 [ 35659 ] {7428e26e-e93c-4a02-b711-95719e16c9d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.234685 [ 35675 ] {8b15e5a7-777e-4dae-bcef-45b856fafaf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 0, should be 2: In scope SELECT tupleDivide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleDivide();) 2025.06.18 11:21:17.239195 [ 35675 ] {8b15e5a7-777e-4dae-bcef-45b856fafaf2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 0, should be 2: In scope SELECT tupleDivide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.260295 [ 35659 ] {51613026-1fa6-44b7-ab62-cb6224b1272f} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isValidJSON(NULL, NULL);) 2025.06.18 11:21:17.265229 [ 35659 ] {51613026-1fa6-44b7-ab62-cb6224b1272f} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.268028 [ 35675 ] {db2fef24-60d5-4c9b-b073-ed6a166fc587} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleDivideByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleDivideByNumber();) 2025.06.18 11:21:17.273318 [ 35675 ] {db2fef24-60d5-4c9b-b073-ed6a166fc587} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleDivideByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.294952 [ 35659 ] {c10cc6ff-eaa3-4ed8-b965-e09f221d29e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isValidUTF8(NULL, NULL);) 2025.06.18 11:21:17.298655 [ 35659 ] {c10cc6ff-eaa3-4ed8-b965-e09f221d29e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.301405 [ 35675 ] {c48eb69b-0d8a-4b25-89d2-78457c14f7fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 0, should be 2 or 3: In scope SELECT tupleElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleElement();) 2025.06.18 11:21:17.305845 [ 35675 ] {c48eb69b-0d8a-4b25-89d2-78457c14f7fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 0, should be 2 or 3: In scope SELECT tupleElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.327748 [ 35659 ] {f918c2db-0f72-4ef1-8c54-f53aeae47f0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isZeroOrNull(NULL, NULL);) 2025.06.18 11:21:17.331835 [ 35659 ] {f918c2db-0f72-4ef1-8c54-f53aeae47f0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.333435 [ 35675 ] {fc69ff63-b8ce-4a29-bf27-8b90013b4d5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 0, should be 2: In scope SELECT tupleHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleHammingDistance();) 2025.06.18 11:21:17.337716 [ 35675 ] {fc69ff63-b8ce-4a29-bf27-8b90013b4d5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 0, should be 2: In scope SELECT tupleHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.364107 [ 35675 ] {f7de1215-68e5-490b-b3ff-f7459595bbca} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 0, should be 2: In scope SELECT tupleIntDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDiv();) 2025.06.18 11:21:17.368367 [ 35675 ] {f7de1215-68e5-490b-b3ff-f7459595bbca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 0, should be 2: In scope SELECT tupleIntDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.394717 [ 35675 ] {5ab08a9c-709a-494c-bb18-2b01cf3ac747} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDivByNumber();) 2025.06.18 11:21:17.398517 [ 35675 ] {5ab08a9c-709a-494c-bb18-2b01cf3ac747} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.421511 [ 35675 ] {8077f73e-10e2-4e8d-a88f-4d62b78e067d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDivOrZero();) 2025.06.18 11:21:17.425376 [ 35675 ] {8077f73e-10e2-4e8d-a88f-4d62b78e067d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.448807 [ 35675 ] {120cda48-f739-45ea-a283-56652a3b2a03} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDivOrZeroByNumber();) 2025.06.18 11:21:17.452481 [ 35675 ] {120cda48-f739-45ea-a283-56652a3b2a03} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.475053 [ 35675 ] {199c601f-31f4-4728-b4e1-2625872a091e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT tupleMinus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleMinus();) 2025.06.18 11:21:17.478694 [ 35675 ] {199c601f-31f4-4728-b4e1-2625872a091e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT tupleMinus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.501907 [ 35675 ] {d310b71b-5f7b-4f31-a5ba-8e963b0d845d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 0, should be 2: In scope SELECT tupleModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleModulo();) 2025.06.18 11:21:17.505824 [ 35675 ] {d310b71b-5f7b-4f31-a5ba-8e963b0d845d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 0, should be 2: In scope SELECT tupleModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.530079 [ 35675 ] {9e5bc365-6750-4cac-97d1-e82a87f64577} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleModuloByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleModuloByNumber();) 2025.06.18 11:21:17.533869 [ 35675 ] {9e5bc365-6750-4cac-97d1-e82a87f64577} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleModuloByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.557755 [ 35675 ] {3049264e-2ecb-4792-8922-876428efcd27} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 0, should be 2: In scope SELECT tupleMultiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleMultiply();) 2025.06.18 11:21:17.561569 [ 35675 ] {3049264e-2ecb-4792-8922-876428efcd27} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 0, should be 2: In scope SELECT tupleMultiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.584371 [ 35675 ] {b996f65e-c97a-4834-887d-a7c8273bcd86} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleMultiplyByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleMultiplyByNumber();) 2025.06.18 11:21:17.588201 [ 35675 ] {b996f65e-c97a-4834-887d-a7c8273bcd86} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleMultiplyByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.595458 [ 35659 ] {4cf556de-aa13-49bc-957b-45f2297b2ef3} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT joinGet(NULL, NULL);) 2025.06.18 11:21:17.598949 [ 35659 ] {4cf556de-aa13-49bc-957b-45f2297b2ef3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.611649 [ 35675 ] {14359b6b-0f92-4e19-989a-8c58037dcccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 0, should be 1: In scope SELECT tupleNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleNames();) 2025.06.18 11:21:17.615307 [ 35675 ] {14359b6b-0f92-4e19-989a-8c58037dcccf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 0, should be 1: In scope SELECT tupleNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.626176 [ 35659 ] {c7826cfc-ad00-4fff-ada7-b9612fbed81d} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT joinGetOrNull(NULL, NULL);) 2025.06.18 11:21:17.629660 [ 35659 ] {c7826cfc-ad00-4fff-ada7-b9612fbed81d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.638973 [ 35675 ] {1d1868ef-9726-4de3-ba69-1ebb205a27ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 0, should be 1: In scope SELECT tupleNegate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleNegate();) 2025.06.18 11:21:17.642674 [ 35675 ] {1d1868ef-9726-4de3-ba69-1ebb205a27ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 0, should be 1: In scope SELECT tupleNegate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.664697 [ 35675 ] {5d6011e2-f678-4b5a-b263-db32e0c5e0b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT tuplePlus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tuplePlus();) 2025.06.18 11:21:17.668495 [ 35675 ] {5d6011e2-f678-4b5a-b263-db32e0c5e0b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT tuplePlus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.691652 [ 35675 ] {1bd59965-5db4-4bfe-8993-2f1e92e55175} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 0, should be 1: In scope SELECT tupleToNameValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleToNameValuePairs();) 2025.06.18 11:21:17.695390 [ 35675 ] {1bd59965-5db4-4bfe-8993-2f1e92e55175} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 0, should be 1: In scope SELECT tupleToNameValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.717767 [ 35675 ] {e35608a5-eaea-480d-84ff-91840e86cd7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT ucase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ucase();) 2025.06.18 11:21:17.721696 [ 35675 ] {e35608a5-eaea-480d-84ff-91840e86cd7c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT ucase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.745103 [ 35675 ] {5af5ec8e-3031-4afa-923f-49382243cf77} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 0, should be 1: In scope SELECT unbin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT unbin();) 2025.06.18 11:21:17.748771 [ 35675 ] {5af5ec8e-3031-4afa-923f-49382243cf77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 0, should be 1: In scope SELECT unbin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.770899 [ 35675 ] {00e57652-c4ca-4c9e-88d1-8d5f9b5e94b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 0, should be 1: In scope SELECT unhex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT unhex();) 2025.06.18 11:21:17.774613 [ 35675 ] {00e57652-c4ca-4c9e-88d1-8d5f9b5e94b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 0, should be 1: In scope SELECT unhex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.798667 [ 35675 ] {64a82a9b-e4ab-444b-bc81-f69010ecc097} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniq. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniq();) 2025.06.18 11:21:17.802891 [ 35675 ] {64a82a9b-e4ab-444b-bc81-f69010ecc097} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniq. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.826587 [ 35675 ] {06e771f3-c683-41a2-883d-f747d76f7d74} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqCombined();) 2025.06.18 11:21:17.830221 [ 35675 ] {06e771f3-c683-41a2-883d-f747d76f7d74} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.853334 [ 35675 ] {c430fb81-d648-48fa-9dfe-4c7310fc6f02} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined64. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqCombined64();) 2025.06.18 11:21:17.857032 [ 35675 ] {c430fb81-d648-48fa-9dfe-4c7310fc6f02} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined64. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.880129 [ 35675 ] {beff57c7-e267-4df2-aaea-706cda5686f3} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqExact. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqExact();) 2025.06.18 11:21:17.883895 [ 35675 ] {beff57c7-e267-4df2-aaea-706cda5686f3} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqExact. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.907323 [ 35675 ] {b1e81854-a2ed-416d-9833-4778e2f114a9} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqHLL12. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqHLL12();) 2025.06.18 11:21:17.911052 [ 35675 ] {b1e81854-a2ed-416d-9833-4778e2f114a9} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqHLL12. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.933965 [ 35675 ] {217d46e6-3d26-4e49-b06c-7fd3cd1eb65e} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqTheta. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqTheta();) 2025.06.18 11:21:17.937854 [ 35675 ] {217d46e6-3d26-4e49-b06c-7fd3cd1eb65e} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqTheta. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.961582 [ 35675 ] {fa03288a-499b-470f-8bfb-da5fdfb1214a} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 0, should be 2: In scope SELECT uniqThetaIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqThetaIntersect();) 2025.06.18 11:21:17.965358 [ 35675 ] {fa03288a-499b-470f-8bfb-da5fdfb1214a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 0, should be 2: In scope SELECT uniqThetaIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:17.988437 [ 35675 ] {8e621af2-e872-4c90-a5db-80204b53f31b} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 0, should be 2: In scope SELECT uniqThetaNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqThetaNot();) 2025.06.18 11:21:17.992146 [ 35675 ] {8e621af2-e872-4c90-a5db-80204b53f31b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 0, should be 2: In scope SELECT uniqThetaNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.014994 [ 35675 ] {03694b20-e0c6-4e43-a2cb-ad0489d945c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 0, should be 2: In scope SELECT uniqThetaUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqThetaUnion();) 2025.06.18 11:21:18.018651 [ 35675 ] {03694b20-e0c6-4e43-a2cb-ad0489d945c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 0, should be 2: In scope SELECT uniqThetaUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.041527 [ 35675 ] {b647b289-da5c-4bca-baef-2111b25e6c67} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqUpTo. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqUpTo();) 2025.06.18 11:21:18.045137 [ 35675 ] {b647b289-da5c-4bca-baef-2111b25e6c67} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqUpTo. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.067530 [ 35675 ] {82fc8544-9b0f-4385-8f7b-3a144b6a3a80} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT upper(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT upper();) 2025.06.18 11:21:18.071331 [ 35675 ] {82fc8544-9b0f-4385-8f7b-3a144b6a3a80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT upper(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.094603 [ 35675 ] {833ec76c-c090-4a1b-a3d1-f2f6a7e1d39f} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 0, should be 1: In scope SELECT upperUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT upperUTF8();) 2025.06.18 11:21:18.098312 [ 35675 ] {833ec76c-c090-4a1b-a3d1-f2f6a7e1d39f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 0, should be 1: In scope SELECT upperUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.209363 [ 35659 ] {4d7e279a-2162-45f8-af10-22a1659a0b94} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lagInFrame(NULL, NULL);) 2025.06.18 11:21:18.212925 [ 35659 ] {4d7e279a-2162-45f8-af10-22a1659a0b94} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.18 11:21:18.226926 [ 35675 ] {6f262eb6-4b29-453f-af22-23c0e9662033} executeQuery: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 0.: In scope SELECT validateNestedArraySizes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT validateNestedArraySizes();) 2025.06.18 11:21:18.230652 [ 35675 ] {6f262eb6-4b29-453f-af22-23c0e9662033} TCPHandler: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 0.: In scope SELECT validateNestedArraySizes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.252775 [ 35675 ] {655c7db4-fe9d-4a4d-9868-041c96446061} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varPop();) 2025.06.18 11:21:18.256172 [ 35675 ] {655c7db4-fe9d-4a4d-9868-041c96446061} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.277992 [ 35675 ] {529d0ef1-65be-417a-bd27-89f3d1d4b7e3} executeQuery: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varPopStable();) 2025.06.18 11:21:18.281625 [ 35675 ] {529d0ef1-65be-417a-bd27-89f3d1d4b7e3} TCPHandler: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.304033 [ 35675 ] {d96997d1-a9ed-4612-94bb-9c14d1c22e75} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varSamp();) 2025.06.18 11:21:18.307828 [ 35675 ] {d96997d1-a9ed-4612-94bb-9c14d1c22e75} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.330294 [ 35675 ] {11888dd0-5e77-446a-b3d9-ade976ac6067} executeQuery: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varSampStable();) 2025.06.18 11:21:18.334041 [ 35675 ] {11888dd0-5e77-446a-b3d9-ade976ac6067} TCPHandler: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.359952 [ 35675 ] {a92fbea7-87f9-4968-8895-47714d04069d} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 0, should be 2 or 3: In scope SELECT variantElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT variantElement();) 2025.06.18 11:21:18.363999 [ 35675 ] {a92fbea7-87f9-4968-8895-47714d04069d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 0, should be 2 or 3: In scope SELECT variantElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.373141 [ 35659 ] {dbe60cb0-6629-4985-bacc-0bba2c3a1196} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT last_value_respect_nulls(NULL, NULL);) 2025.06.18 11:21:18.376550 [ 35659 ] {dbe60cb0-6629-4985-bacc-0bba2c3a1196} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.390885 [ 35675 ] {60b7d42a-4775-4e1e-b31c-705dd415b2a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT variantType();) 2025.06.18 11:21:18.394715 [ 35675 ] {60b7d42a-4775-4e1e-b31c-705dd415b2a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.403781 [ 35659 ] {ef61e145-2010-451b-8d56-ab5d2a166f06} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lcase(NULL, NULL);) 2025.06.18 11:21:18.407678 [ 35659 ] {ef61e145-2010-451b-8d56-ab5d2a166f06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.417730 [ 35675 ] {4e3f4fa2-4807-4e9e-8770-128535607224} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT vectorDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT vectorDifference();) 2025.06.18 11:21:18.421410 [ 35675 ] {4e3f4fa2-4807-4e9e-8770-128535607224} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT vectorDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.442892 [ 35675 ] {c4eb8f31-2e38-412b-93f6-15f646582b12} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT vectorSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT vectorSum();) 2025.06.18 11:21:18.446272 [ 35675 ] {c4eb8f31-2e38-412b-93f6-15f646582b12} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT vectorSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.487546 [ 35659 ] {c7553f77-a57d-48ec-9d65-9854c9430dc9} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT leadInFrame(NULL, NULL);) 2025.06.18 11:21:18.490979 [ 35659 ] {c7553f77-a57d-48ec-9d65-9854c9430dc9} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.18 11:21:18.514948 [ 35675 ] {5c8c4995-39c2-4452-a23c-7223ecfef1d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 0, should be 1: In scope SELECT visibleWidth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visibleWidth();) 2025.06.18 11:21:18.518770 [ 35675 ] {5c8c4995-39c2-4452-a23c-7223ecfef1d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 0, should be 1: In scope SELECT visibleWidth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.541655 [ 35675 ] {d5464089-dce1-4614-a82e-eaa1889ac0cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractBool();) 2025.06.18 11:21:18.545209 [ 35675 ] {d5464089-dce1-4614-a82e-eaa1889ac0cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.569355 [ 35675 ] {6cb08a49-8e0c-433c-8ff8-3c85f7424c9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractFloat();) 2025.06.18 11:21:18.572918 [ 35675 ] {6cb08a49-8e0c-433c-8ff8-3c85f7424c9b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.594710 [ 35675 ] {4b338d18-3055-4a51-b86e-b61009f1afb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractInt();) 2025.06.18 11:21:18.598133 [ 35675 ] {4b338d18-3055-4a51-b86e-b61009f1afb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.621862 [ 35675 ] {3f231e20-fd90-4149-8cb7-5182e60a60f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractRaw();) 2025.06.18 11:21:18.625500 [ 35675 ] {3f231e20-fd90-4149-8cb7-5182e60a60f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.649240 [ 35675 ] {3e5fade2-9616-422d-9734-0de9aae92321} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractString();) 2025.06.18 11:21:18.653362 [ 35675 ] {3e5fade2-9616-422d-9734-0de9aae92321} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.654576 [ 35669 ] {623a789d-0c5c-4632-a1d0-f92220558ab3} executeQuery: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40576) (comment: 01451_replicated_detach_drop_part_long.sql) (in query: ALTER TABLE replica1 DETACH PART 'all_100_100_0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5081: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397c0290 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:18.656693 [ 35669 ] {623a789d-0c5c-4632-a1d0-f92220558ab3} TCPHandler: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5081: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397c0290 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d29e9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:18.677730 [ 35675 ] {963a643d-c3dd-4d8a-91a7-8ac3274c43b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractUInt();) 2025.06.18 11:21:18.681382 [ 35675 ] {963a643d-c3dd-4d8a-91a7-8ac3274c43b3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.703749 [ 35675 ] {cd1fc292-e5c2-430f-9290-84c954e2a565} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT visitParamHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamHas();) 2025.06.18 11:21:18.707470 [ 35675 ] {cd1fc292-e5c2-430f-9290-84c954e2a565} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT visitParamHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.730249 [ 35675 ] {4750667b-a357-4fd1-87bb-862ccade3707} executeQuery: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT week(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT week();) 2025.06.18 11:21:18.734218 [ 35675 ] {4750667b-a357-4fd1-87bb-862ccade3707} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT week(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.757400 [ 35675 ] {1c1d23ba-56aa-426c-ab18-73014b61bd0f} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT welchTTest();) 2025.06.18 11:21:18.761468 [ 35675 ] {1c1d23ba-56aa-426c-ab18-73014b61bd0f} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.780146 [ 35659 ] {a669cf13-1326-4e3c-8191-494b03a8a714} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lemmatize(NULL, NULL);) 2025.06.18 11:21:18.784469 [ 35659 ] {a669cf13-1326-4e3c-8191-494b03a8a714} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:18.784500 [ 35675 ] {99b1d13f-9927-4c53-b5b8-b2e137eea13f} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT widthBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT widthBucket();) 2025.06.18 11:21:18.788518 [ 35675 ] {99b1d13f-9927-4c53-b5b8-b2e137eea13f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT widthBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.812134 [ 35675 ] {13bafced-8632-41ff-a849-e65bc75bd371} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT width_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT width_bucket();) 2025.06.18 11:21:18.812446 [ 35659 ] {96bdbd98-a940-498e-a532-6226d5662998} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT length(NULL, NULL);) 2025.06.18 11:21:18.816097 [ 35675 ] {13bafced-8632-41ff-a849-e65bc75bd371} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT width_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.816930 [ 35659 ] {96bdbd98-a940-498e-a532-6226d5662998} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.838651 [ 35675 ] {dbcab09d-4dba-481c-af65-0649b062bed9} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT windowFunnel();) 2025.06.18 11:21:18.842516 [ 35675 ] {dbcab09d-4dba-481c-af65-0649b062bed9} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.844410 [ 35659 ] {30dd6262-4d7f-44fb-b420-f1231e401693} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lengthUTF8(NULL, NULL);) 2025.06.18 11:21:18.847913 [ 35659 ] {30dd6262-4d7f-44fb-b420-f1231e401693} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.865101 [ 35675 ] {f9667c63-bef5-4ae9-b2d0-32e761b49fb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT windowID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT windowID();) 2025.06.18 11:21:18.868635 [ 35675 ] {f9667c63-bef5-4ae9-b2d0-32e761b49fb2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT windowID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.891894 [ 35675 ] {2ef1bbc9-3a74-4d46-88b1-f10d3ca59607} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 0, should be 1: In scope SELECT wkt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wkt();) 2025.06.18 11:21:18.895843 [ 35675 ] {2ef1bbc9-3a74-4d46-88b1-f10d3ca59607} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 0, should be 1: In scope SELECT wkt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:18.918007 [ 35675 ] {77afd523-9005-4d67-919a-2d0bf97068a1} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHash expect at least one argument: In scope SELECT wordShingleMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHash();) 2025.06.18 11:21:18.921600 [ 35675 ] {77afd523-9005-4d67-919a-2d0bf97068a1} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHash expect at least one argument: In scope SELECT wordShingleMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:18.944071 [ 35675 ] {ba90b2d9-0d23-46b7-9904-0e49ac4a3f72} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArg expect at least one argument: In scope SELECT wordShingleMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArg();) 2025.06.18 11:21:18.947667 [ 35675 ] {ba90b2d9-0d23-46b7-9904-0e49ac4a3f72} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArg expect at least one argument: In scope SELECT wordShingleMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:18.969993 [ 35675 ] {319eb24a-4529-4ed0-8ae0-b2ea3393cd20} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitive();) 2025.06.18 11:21:18.973621 [ 35675 ] {319eb24a-4529-4ed0-8ae0-b2ea3393cd20} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:18.995984 [ 35675 ] {851ec776-8b1a-4724-ab4c-3877349fea33} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8();) 2025.06.18 11:21:18.999694 [ 35675 ] {851ec776-8b1a-4724-ab4c-3877349fea33} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.022458 [ 35675 ] {336297e1-e35f-4f62-b946-f167c703ca82} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArgUTF8();) 2025.06.18 11:21:19.025991 [ 35675 ] {336297e1-e35f-4f62-b946-f167c703ca82} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.039588 [ 1275 ] {} test_b2peb6e2.replica1 (0f3616ec-184b-4b65-835b-8b056ab790d4): Part all_3_3_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.06.18 11:21:19.048933 [ 35675 ] {0b4d6b52-293a-41a8-ac33-3ca758d636ec} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashCaseInsensitive();) 2025.06.18 11:21:19.052966 [ 35675 ] {0b4d6b52-293a-41a8-ac33-3ca758d636ec} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.075249 [ 35675 ] {dfe7c0f4-481f-4308-86b8-11ba8b43c16d} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8();) 2025.06.18 11:21:19.078994 [ 35675 ] {dfe7c0f4-481f-4308-86b8-11ba8b43c16d} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.080568 [ 35659 ] {a40a4de9-ca44-4ea0-9005-f04f817593be} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lgamma(NULL, NULL);) 2025.06.18 11:21:19.084539 [ 35659 ] {a40a4de9-ca44-4ea0-9005-f04f817593be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.101272 [ 35675 ] {0d6d9340-a0ea-4dae-a3e2-d04590861d3e} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashUTF8 expect at least one argument: In scope SELECT wordShingleMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashUTF8();) 2025.06.18 11:21:19.104839 [ 35675 ] {0d6d9340-a0ea-4dae-a3e2-d04590861d3e} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashUTF8 expect at least one argument: In scope SELECT wordShingleMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.130348 [ 35675 ] {7985e12b-92d5-41d3-9cf3-eb5a7aa13111} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHash expect at least one argument: In scope SELECT wordShingleSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHash();) 2025.06.18 11:21:19.134406 [ 35675 ] {7985e12b-92d5-41d3-9cf3-eb5a7aa13111} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHash expect at least one argument: In scope SELECT wordShingleSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.157134 [ 35659 ] {be1b041a-cf91-4556-8316-78aa9f755e05} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ln(NULL, NULL);) 2025.06.18 11:21:19.157134 [ 35675 ] {4a3fcbf9-b985-4732-890f-58c1e7f0fdd3} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHashCaseInsensitive();) 2025.06.18 11:21:19.160511 [ 35659 ] {be1b041a-cf91-4556-8316-78aa9f755e05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.160511 [ 35675 ] {4a3fcbf9-b985-4732-890f-58c1e7f0fdd3} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.182213 [ 35675 ] {d99753a7-599b-4e41-ae00-64d00eb2c609} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8();) 2025.06.18 11:21:19.185563 [ 35675 ] {d99753a7-599b-4e41-ae00-64d00eb2c609} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.206242 [ 35675 ] {70546f00-ccf8-4416-ae60-2a965d1a62f1} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashUTF8 expect at least one argument: In scope SELECT wordShingleSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHashUTF8();) 2025.06.18 11:21:19.209607 [ 35675 ] {70546f00-ccf8-4416-ae60-2a965d1a62f1} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashUTF8 expect at least one argument: In scope SELECT wordShingleSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.231130 [ 35659 ] {5601d279-6e3d-42f3-a996-366e1713d4f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log(NULL, NULL);) 2025.06.18 11:21:19.281752 [ 35659 ] {5601d279-6e3d-42f3-a996-366e1713d4f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.310899 [ 35659 ] {427c2a6c-a104-4dcc-bde4-41d60da3f527} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log10(NULL, NULL);) 2025.06.18 11:21:19.312388 [ 35675 ] {e825c7f9-45e5-47c2-bf2d-aadc3a61517f} executeQuery: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 0: In scope SELECT xor(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT xor();) 2025.06.18 11:21:19.314979 [ 35659 ] {427c2a6c-a104-4dcc-bde4-41d60da3f527} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.314979 [ 35675 ] {e825c7f9-45e5-47c2-bf2d-aadc3a61517f} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 0: In scope SELECT xor(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.18 11:21:19.341567 [ 35659 ] {2d1a4be6-c4a5-489f-adf7-dd86a700dc7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log1p(NULL, NULL);) 2025.06.18 11:21:19.345366 [ 35659 ] {2d1a4be6-c4a5-489f-adf7-dd86a700dc7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.375415 [ 35659 ] {26310dcf-0215-4c40-8b7c-3b2d2fca263b} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log2(NULL, NULL);) 2025.06.18 11:21:19.379118 [ 35659 ] {26310dcf-0215-4c40-8b7c-3b2d2fca263b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.408065 [ 35659 ] {4784c6fe-94d1-4479-bead-81e091e93439} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT logTrace(NULL, NULL);) 2025.06.18 11:21:19.411535 [ 35659 ] {4784c6fe-94d1-4479-bead-81e091e93439} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.438617 [ 35659 ] {551a083a-4841-45d4-8376-e5ab6d64cc85} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lowCardinalityIndices(NULL, NULL);) 2025.06.18 11:21:19.441969 [ 35659 ] {551a083a-4841-45d4-8376-e5ab6d64cc85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.469609 [ 35659 ] {d0fc93d6-8a9b-4c38-9b5a-5c90c9ebcccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lowCardinalityKeys(NULL, NULL);) 2025.06.18 11:21:19.473081 [ 35659 ] {d0fc93d6-8a9b-4c38-9b5a-5c90c9ebcccf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.479045 [ 35675 ] {f2c0821f-a044-4e45-808e-7306c9bee636} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT yandexConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT yandexConsistentHash();) 2025.06.18 11:21:19.482453 [ 35675 ] {f2c0821f-a044-4e45-808e-7306c9bee636} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT yandexConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.500746 [ 35659 ] {e78387ac-c4ce-46cf-9ca9-fade5be01c47} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lower(NULL, NULL);) 2025.06.18 11:21:19.502095 [ 35675 ] {19aeafc4-d2bb-4677-ad80-7f866fe75819} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT yearweek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35328) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT yearweek();) 2025.06.18 11:21:19.504322 [ 35659 ] {e78387ac-c4ce-46cf-9ca9-fade5be01c47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.505341 [ 35675 ] {19aeafc4-d2bb-4677-ad80-7f866fe75819} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT yearweek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.533481 [ 35659 ] {537fa02e-3b0f-4c77-8e2b-f4b9896deed5} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lowerUTF8(NULL, NULL);) 2025.06.18 11:21:19.536986 [ 35659 ] {537fa02e-3b0f-4c77-8e2b-f4b9896deed5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:19.935810 [ 35659 ] {9693e82b-6a94-4f13-b1e8-3d3c4aa9f315} executeQuery: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT map(NULL, NULL);) 2025.06.18 11:21:19.939098 [ 35659 ] {9693e82b-6a94-4f13-b1e8-3d3c4aa9f315} TCPHandler: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:20.150434 [ 35659 ] {85af831c-a0e3-4945-91d3-ee854edc1b40} executeQuery: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapContains(NULL, NULL);) 2025.06.18 11:21:20.150462 [ 35669 ] {12e1235e-d32c-4046-b62a-d1bcbf7f77ed} executeQuery: Code: 233. DB::Exception: Detached part "all_3_3_0" not found. (BAD_DATA_PART_NAME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40576) (comment: 01451_replicated_detach_drop_part_long.sql) (in query: ALTER TABLE replica1 ATTACH PART 'all_3_3_0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7477: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x00000000397f9e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6327: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x00000000397fbd34 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6618: DB::StorageReplicatedMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003892efcf 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397cf4de 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:20.152401 [ 35669 ] {12e1235e-d32c-4046-b62a-d1bcbf7f77ed} TCPHandler: Code: 233. DB::Exception: Detached part "all_3_3_0" not found. (BAD_DATA_PART_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7477: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x00000000397f9e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6327: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x00000000397fbd34 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6618: DB::StorageReplicatedMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003892efcf 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397cf4de 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:20.153548 [ 35659 ] {85af831c-a0e3-4945-91d3-ee854edc1b40} TCPHandler: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:20.365616 [ 35659 ] {0e5fc7bf-4f64-494f-bdb9-3f8277fb394b} executeQuery: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT mapFromArrays(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapFromArrays(NULL, NULL);) 2025.06.18 11:21:20.369519 [ 35659 ] {0e5fc7bf-4f64-494f-bdb9-3f8277fb394b} TCPHandler: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT mapFromArrays(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:20.448873 [ 35659 ] {85d5285c-0ab3-48bd-9942-0e1abc61a87f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapKeys(NULL, NULL);) 2025.06.18 11:21:20.452384 [ 35659 ] {85d5285c-0ab3-48bd-9942-0e1abc61a87f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:20.854790 [ 35659 ] {d795e9a4-eb71-45ea-8883-51afce3fa4b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapValues(NULL, NULL);) 2025.06.18 11:21:20.858310 [ 35659 ] {d795e9a4-eb71-45ea-8883-51afce3fa4b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:20.936584 [ 35659 ] {b5750736-5d29-4e78-928b-141a04c7c5eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT materialize(NULL, NULL);) 2025.06.18 11:21:20.940421 [ 35659 ] {b5750736-5d29-4e78-928b-141a04c7c5eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:21.022869 [ 35674 ] {35a4ee01-47cc-4537-ba91-619caf0b1fb5} executeQuery: Code: 36. DB::Exception: Primary key cannot be updated (cannot update column key). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40656) (comment: 02416_rocksdb_delete_update.sql) (in query: ALTER TABLE 02416_rocksdb UPDATE key = key * 10 WHERE 1 = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:298: DB::StorageEmbeddedRocksDB::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000030c43c75 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:21.024963 [ 35674 ] {35a4ee01-47cc-4537-ba91-619caf0b1fb5} TCPHandler: Code: 36. DB::Exception: Primary key cannot be updated (cannot update column key). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:298: DB::StorageEmbeddedRocksDB::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000030c43c75 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:22.651802 [ 35659 ] {c548f28d-0ae4-4d7f-9f3d-ebc41a4cda6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT minSampleSizeContinous(NULL, NULL);) 2025.06.18 11:21:22.655237 [ 35659 ] {c548f28d-0ae4-4d7f-9f3d-ebc41a4cda6d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:22.680429 [ 35659 ] {296ed881-847e-4c7b-8bc7-07ed1a9d7a06} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT minSampleSizeContinuous(NULL, NULL);) 2025.06.18 11:21:22.683958 [ 35659 ] {296ed881-847e-4c7b-8bc7-07ed1a9d7a06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:22.710494 [ 35659 ] {4e5abaf5-6c04-48ef-80f4-e1ef4f54c37c} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT minSampleSizeConversion(NULL, NULL);) 2025.06.18 11:21:22.714093 [ 35659 ] {4e5abaf5-6c04-48ef-80f4-e1ef4f54c37c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:23.043933 [ 35659 ] {1b5b6923-982a-4538-a071-e5e0af2fdc77} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT monthName(NULL, NULL);) 2025.06.18 11:21:23.047660 [ 35659 ] {1b5b6923-982a-4538-a071-e5e0af2fdc77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:23.181217 [ 35659 ] {1fc650e7-2a1e-463e-a8ce-29e09be46919} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiFuzzyMatchAllIndices(NULL, NULL);) 2025.06.18 11:21:23.184951 [ 35659 ] {1fc650e7-2a1e-463e-a8ce-29e09be46919} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:23.212813 [ 35659 ] {b83a73f0-c068-4812-b62e-c84050de0e1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiFuzzyMatchAny(NULL, NULL);) 2025.06.18 11:21:23.216336 [ 35659 ] {b83a73f0-c068-4812-b62e-c84050de0e1e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:23.240371 [ 35659 ] {6307b30a-fffc-499f-b6fc-4f81f932cc32} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiFuzzyMatchAnyIndex(NULL, NULL);) 2025.06.18 11:21:23.243835 [ 35659 ] {6307b30a-fffc-499f-b6fc-4f81f932cc32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:23.271096 [ 35659 ] {20f900f0-0b2c-4efe-98e9-e5e1f48d9545} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiIf(NULL, NULL);) 2025.06.18 11:21:23.274699 [ 35659 ] {20f900f0-0b2c-4efe-98e9-e5e1f48d9545} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:24.406858 [ 35669 ] {9ab07ea1-1b4a-4dc8-81ba-2fb6925cb3c1} executeQuery: Code: 130. DB::Exception: Array does not start with '[' character: value Hello cannot be parsed as Array(String) for query parameter 'x'. (CANNOT_READ_ARRAY_FROM_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33496) (comment: 02723_param_exception_message_context.sh) (in query: SELECT {x:Array(String)}), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:442: DB::SerializationArray::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000003265f88d 5. DB::SimpleTextSerialization::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008620623 6. ./src/IO/BufferBase.h:86: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000035840534 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ed56 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 15. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 16. ./src/Interpreters/ReplaceQueryParameterVisitor.h:23: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589b967 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:24.418020 [ 35669 ] {9ab07ea1-1b4a-4dc8-81ba-2fb6925cb3c1} TCPHandler: Code: 130. DB::Exception: Array does not start with '[' character: value Hello cannot be parsed as Array(String) for query parameter 'x'. (CANNOT_READ_ARRAY_FROM_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:442: DB::SerializationArray::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000003265f88d 5. DB::SimpleTextSerialization::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008620623 6. ./src/IO/BufferBase.h:86: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000035840534 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ed56 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x0000000035842b12 15. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x000000003583ef57 16. ./src/Interpreters/ReplaceQueryParameterVisitor.h:23: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589b967 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:24.749964 [ 35659 ] {3cc10a43-9a82-4ef4-af46-9695eab62227} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT negate(NULL, NULL);) 2025.06.18 11:21:24.753598 [ 35659 ] {3cc10a43-9a82-4ef4-af46-9695eab62227} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:24.778019 [ 35659 ] {d1a38816-f384-448d-ba43-43aa4212ad80} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT neighbor(NULL, NULL);) 2025.06.18 11:21:24.781484 [ 35659 ] {d1a38816-f384-448d-ba43-43aa4212ad80} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:21:24.886593 [ 35659 ] {72747bf6-651a-479e-913f-405642ca6dd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT netloc(NULL, NULL);) 2025.06.18 11:21:24.889987 [ 35659 ] {72747bf6-651a-479e-913f-405642ca6dd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.069128 [ 35659 ] {92a15b70-9cea-451b-b22f-9429b1a916da} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT nonNegativeDerivative(NULL, NULL);) 2025.06.18 11:21:26.072591 [ 35659 ] {92a15b70-9cea-451b-b22f-9429b1a916da} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.18 11:21:26.096844 [ 35659 ] {7e9faa32-d098-4ae5-9d4d-9134a1656dd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normL1(NULL, NULL);) 2025.06.18 11:21:26.100297 [ 35659 ] {7e9faa32-d098-4ae5-9d4d-9134a1656dd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.124059 [ 35659 ] {48fa27a9-0549-4083-a08a-48e6457f81e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normL2(NULL, NULL);) 2025.06.18 11:21:26.127270 [ 35659 ] {48fa27a9-0549-4083-a08a-48e6457f81e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.152214 [ 35659 ] {17396c80-208a-41ff-a34d-487d04b36f19} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normL2Squared(NULL, NULL);) 2025.06.18 11:21:26.155349 [ 35659 ] {17396c80-208a-41ff-a34d-487d04b36f19} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.179918 [ 35659 ] {36bf58f4-66aa-457e-83c5-e451d99dd7b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normLinf(NULL, NULL);) 2025.06.18 11:21:26.183832 [ 35659 ] {36bf58f4-66aa-457e-83c5-e451d99dd7b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.260369 [ 35659 ] {130dba7b-4615-4f0b-94db-0b2b24c689e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeL1(NULL, NULL);) 2025.06.18 11:21:26.263820 [ 35659 ] {130dba7b-4615-4f0b-94db-0b2b24c689e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.277951 [ 51855 ] {24817a34-2163-4a40-9e96-c955e24f0273} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736626689. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33604) (comment: 02426_pod_array_overflow_3.sql) (in query: SELECT * FROM format(Native, '\x01\x01\x01x\x0CArray(UInt8)\x01\x00\xBD\xEF\xBF\xBD\xEF\xBF\xBD\xEF');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad987e3 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fec124c 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:26.280227 [ 51855 ] {24817a34-2163-4a40-9e96-c955e24f0273} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736626689. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad987e3 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fec124c 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:26.291287 [ 35659 ] {5a35e9af-02bd-474c-a904-8f765a40a12a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeL2(NULL, NULL);) 2025.06.18 11:21:26.294601 [ 35659 ] {5a35e9af-02bd-474c-a904-8f765a40a12a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.321588 [ 35659 ] {553d3998-0ace-4554-ae92-5ead872b12fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeLinf(NULL, NULL);) 2025.06.18 11:21:26.325398 [ 35659 ] {553d3998-0ace-4554-ae92-5ead872b12fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.409320 [ 35659 ] {52ee019f-c389-4014-9fa6-ed3395cb4897} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeQuery(NULL, NULL);) 2025.06.18 11:21:26.413124 [ 35659 ] {52ee019f-c389-4014-9fa6-ed3395cb4897} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.438967 [ 35659 ] {1be74bae-abcd-495a-9678-b57087c6d358} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeQueryKeepNames(NULL, NULL);) 2025.06.18 11:21:26.442580 [ 35659 ] {1be74bae-abcd-495a-9678-b57087c6d358} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.469446 [ 35659 ] {b80825e9-55b7-48c1-9327-c1eb6b10c467} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFC(NULL, NULL);) 2025.06.18 11:21:26.473388 [ 35659 ] {b80825e9-55b7-48c1-9327-c1eb6b10c467} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.497872 [ 35659 ] {0bae2077-714f-417e-a4cd-ee0d5ec43ccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFD(NULL, NULL);) 2025.06.18 11:21:26.501170 [ 35659 ] {0bae2077-714f-417e-a4cd-ee0d5ec43ccf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.525536 [ 35659 ] {9787df34-4873-4e39-a985-8eaf5d7fca5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFKC(NULL, NULL);) 2025.06.18 11:21:26.528818 [ 35659 ] {9787df34-4873-4e39-a985-8eaf5d7fca5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.554336 [ 35659 ] {8d4bdd60-c773-4a51-8f27-0473f27ae279} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFKD(NULL, NULL);) 2025.06.18 11:21:26.557567 [ 35659 ] {8d4bdd60-c773-4a51-8f27-0473f27ae279} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.583859 [ 35659 ] {dd5f05bb-2148-4c09-beab-e9361487664d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizedQueryHash(NULL, NULL);) 2025.06.18 11:21:26.586999 [ 35659 ] {dd5f05bb-2148-4c09-beab-e9361487664d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.613500 [ 35659 ] {d99f3062-8d57-4e5f-992e-ce879a50295a} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL);) 2025.06.18 11:21:26.616802 [ 35659 ] {d99f3062-8d57-4e5f-992e-ce879a50295a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.642672 [ 35659 ] {6ea1a4e1-cc55-423a-ace6-121cf92b51cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT not(NULL, NULL);) 2025.06.18 11:21:26.646082 [ 35659 ] {6ea1a4e1-cc55-423a-ace6-121cf92b51cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:26.671366 [ 35659 ] {0a0eae3e-9da5-4789-9d7b-215e7853ff64} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT notEmpty(NULL, NULL);) 2025.06.18 11:21:26.674823 [ 35659 ] {0a0eae3e-9da5-4789-9d7b-215e7853ff64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:27.266507 [ 35659 ] {7303395e-df35-428a-b501-225630c631f0} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT now(NULL, NULL);) 2025.06.18 11:21:27.270066 [ 35659 ] {7303395e-df35-428a-b501-225630c631f0} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:27.393074 [ 35659 ] {42e03c45-2606-4271-b549-15a44e3cfec1} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT nth_value(NULL, NULL);) 2025.06.18 11:21:27.396478 [ 35659 ] {42e03c45-2606-4271-b549-15a44e3cfec1} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.18 11:21:27.427979 [ 35659 ] {a36635f0-b13c-4273-ab61-becd684a562f} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ntile(NULL, NULL);) 2025.06.18 11:21:27.440632 [ 35659 ] {a36635f0-b13c-4273-ab61-becd684a562f} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.043647 [ 35659 ] {9f112f25-74a3-4afd-8358-d4ea05992806} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT parseReadableSize(NULL, NULL);) 2025.06.18 11:21:29.048989 [ 35659 ] {9f112f25-74a3-4afd-8358-d4ea05992806} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.083743 [ 35659 ] {620bc105-9015-43c0-8de9-849a331476e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT parseReadableSizeOrNull(NULL, NULL);) 2025.06.18 11:21:29.088679 [ 35659 ] {620bc105-9015-43c0-8de9-849a331476e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.121956 [ 35659 ] {166f7dd5-09a4-4162-8f0f-0d90a8262c4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT parseReadableSizeOrZero(NULL, NULL);) 2025.06.18 11:21:29.126711 [ 35659 ] {166f7dd5-09a4-4162-8f0f-0d90a8262c4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.365690 [ 35659 ] {7fde8dc7-a091-4a52-90a8-9b54f36d3e13} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT path(NULL, NULL);) 2025.06.18 11:21:29.370602 [ 35659 ] {7fde8dc7-a091-4a52-90a8-9b54f36d3e13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.403262 [ 35659 ] {90b36101-bb35-4244-bfab-a0aef90fd008} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT pathFull(NULL, NULL);) 2025.06.18 11:21:29.407851 [ 35659 ] {90b36101-bb35-4244-bfab-a0aef90fd008} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.475540 [ 35659 ] {82983d4a-1f47-402b-9f0d-38e2fa993c96} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT percentRank(NULL, NULL);) 2025.06.18 11:21:29.482451 [ 35659 ] {82983d4a-1f47-402b-9f0d-38e2fa993c96} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:29.567845 [ 35659 ] {0a89515d-27bf-4917-a354-cbc878ef66fb} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT percent_rank(NULL, NULL);) 2025.06.18 11:21:29.574966 [ 35659 ] {0a89515d-27bf-4917-a354-cbc878ef66fb} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:29.611912 [ 35659 ] {958976a6-079f-49d0-a9c0-a2837c4e0a92} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT pi(NULL, NULL);) 2025.06.18 11:21:29.617055 [ 35659 ] {958976a6-079f-49d0-a9c0-a2837c4e0a92} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.927400 [ 35659 ] {98e027c0-f3b3-46e5-8153-2e885da1fca4} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonAreaCartesian(NULL, NULL);) 2025.06.18 11:21:29.931911 [ 35659 ] {98e027c0-f3b3-46e5-8153-2e885da1fca4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:29.962284 [ 35659 ] {ebe2155d-3ee8-4981-aab0-0388e467a89a} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonAreaSpherical(NULL, NULL);) 2025.06.18 11:21:29.967274 [ 35659 ] {ebe2155d-3ee8-4981-aab0-0388e467a89a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:30.000671 [ 35659 ] {6bfd8ba4-95b9-4ddf-8a02-ee8c8a9ffa79} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonConvexHullCartesian(NULL, NULL);) 2025.06.18 11:21:30.005387 [ 35659 ] {6bfd8ba4-95b9-4ddf-8a02-ee8c8a9ffa79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:30.036262 [ 35659 ] {8157dfa6-319c-4a8a-8f7a-71ec893a1a54} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonPerimeterCartesian(NULL, NULL);) 2025.06.18 11:21:30.040953 [ 35659 ] {8157dfa6-319c-4a8a-8f7a-71ec893a1a54} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:30.079949 [ 35659 ] {e03f98c8-278f-4ccf-805f-713fe5ddbdda} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonPerimeterSpherical(NULL, NULL);) 2025.06.18 11:21:30.085942 [ 35659 ] {e03f98c8-278f-4ccf-805f-713fe5ddbdda} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:31.580716 [ 35659 ] {a6f558c6-4762-4ab2-b5b3-5d201a6f8757} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT proportionsZTest(NULL, NULL);) 2025.06.18 11:21:31.585451 [ 35659 ] {a6f558c6-4762-4ab2-b5b3-5d201a6f8757} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:31.620023 [ 35659 ] {31b3e3db-8e09-4035-82a2-75d90731dc09} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT protocol(NULL, NULL);) 2025.06.18 11:21:31.625006 [ 35659 ] {31b3e3db-8e09-4035-82a2-75d90731dc09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:31.657377 [ 35659 ] {a34be855-5829-4bbf-9e56-f555db2f8bd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT punycodeDecode(NULL, NULL);) 2025.06.18 11:21:31.662126 [ 35659 ] {a34be855-5829-4bbf-9e56-f555db2f8bd7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:31.695002 [ 35659 ] {b04e0467-4874-4b29-958e-1e6ca8d907ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT punycodeEncode(NULL, NULL);) 2025.06.18 11:21:31.700336 [ 35659 ] {b04e0467-4874-4b29-958e-1e6ca8d907ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:33.246996 [ 35659 ] {f031a6e8-3417-422c-a9ce-d45329632ce6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantiles(NULL, NULL);) 2025.06.18 11:21:33.252403 [ 35659 ] {f031a6e8-3417-422c-a9ce-d45329632ce6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.280760 [ 35659 ] {3d45961f-aea7-4df4-8ad6-f5bdda2c3f06} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesBFloat16(NULL, NULL);) 2025.06.18 11:21:33.284688 [ 35659 ] {3d45961f-aea7-4df4-8ad6-f5bdda2c3f06} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.395115 [ 35659 ] {50e177d7-a97c-42cb-bcb5-9966e587a2f5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesDD(NULL, NULL);) 2025.06.18 11:21:33.399471 [ 35659 ] {50e177d7-a97c-42cb-bcb5-9966e587a2f5} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.428315 [ 35659 ] {bc6449d2-5100-47b6-beec-596e39f67080} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesDeterministic(NULL, NULL);) 2025.06.18 11:21:33.432243 [ 35659 ] {bc6449d2-5100-47b6-beec-596e39f67080} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.461958 [ 35659 ] {8531a7da-2a09-45c7-9a59-90576fba0fab} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExact(NULL, NULL);) 2025.06.18 11:21:33.465918 [ 35659 ] {8531a7da-2a09-45c7-9a59-90576fba0fab} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.494945 [ 35659 ] {59bb85b1-05ef-4c87-bbc8-fd6c00b8ad7d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactExclusive(NULL, NULL);) 2025.06.18 11:21:33.498902 [ 35659 ] {59bb85b1-05ef-4c87-bbc8-fd6c00b8ad7d} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.525182 [ 35659 ] {1bb91f0f-d3d7-46a3-9486-5793d47886d2} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactHigh(NULL, NULL);) 2025.06.18 11:21:33.529617 [ 35659 ] {1bb91f0f-d3d7-46a3-9486-5793d47886d2} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.557894 [ 35659 ] {5b671847-a01c-456f-a036-08723833de33} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactInclusive(NULL, NULL);) 2025.06.18 11:21:33.563107 [ 35659 ] {5b671847-a01c-456f-a036-08723833de33} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.590125 [ 35659 ] {15cc38d2-fa6a-4df1-b07f-a9e59bea542d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactLow(NULL, NULL);) 2025.06.18 11:21:33.594094 [ 35659 ] {15cc38d2-fa6a-4df1-b07f-a9e59bea542d} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.620725 [ 35659 ] {ba9bcb45-55df-4bd2-a210-33bb1051cb13} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactWeighted(NULL, NULL);) 2025.06.18 11:21:33.624883 [ 35659 ] {ba9bcb45-55df-4bd2-a210-33bb1051cb13} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.653944 [ 35659 ] {6a6f21b5-6aec-4471-9bcc-d082af2608bf} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesGK(NULL, NULL);) 2025.06.18 11:21:33.657677 [ 35659 ] {6a6f21b5-6aec-4471-9bcc-d082af2608bf} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.686218 [ 35659 ] {b2cee25c-470d-482f-89b8-33fdf083b49c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL);) 2025.06.18 11:21:33.689983 [ 35659 ] {b2cee25c-470d-482f-89b8-33fdf083b49c} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.716433 [ 35659 ] {994c59e7-5935-44ac-b7e9-9a5a213f02dc} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTDigest(NULL, NULL);) 2025.06.18 11:21:33.720044 [ 35659 ] {994c59e7-5935-44ac-b7e9-9a5a213f02dc} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.746179 [ 35659 ] {196c2d85-f4bb-431a-af6d-2a7b3193e706} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTDigestWeighted(NULL, NULL);) 2025.06.18 11:21:33.749985 [ 35659 ] {196c2d85-f4bb-431a-af6d-2a7b3193e706} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.776946 [ 35659 ] {4a7fddcd-dd9e-4bee-885a-03cc5d2d5095} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTiming(NULL, NULL);) 2025.06.18 11:21:33.780657 [ 35659 ] {4a7fddcd-dd9e-4bee-885a-03cc5d2d5095} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.807578 [ 35659 ] {94e64407-d756-4678-9e11-22e647149772} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTimingWeighted(NULL, NULL);) 2025.06.18 11:21:33.811388 [ 35659 ] {94e64407-d756-4678-9e11-22e647149772} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:33.838753 [ 35659 ] {78db9583-7215-4087-833a-6f69632c0365} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT queryID(NULL, NULL);) 2025.06.18 11:21:33.842426 [ 35659 ] {78db9583-7215-4087-833a-6f69632c0365} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:33.870484 [ 35659 ] {9cc03096-8279-407a-bf88-e42cfea5f900} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT queryString(NULL, NULL);) 2025.06.18 11:21:33.874936 [ 35659 ] {9cc03096-8279-407a-bf88-e42cfea5f900} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:33.901640 [ 35659 ] {cb8bfbb4-4f45-4616-bd22-412e869e4e64} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT queryStringAndFragment(NULL, NULL);) 2025.06.18 11:21:33.905473 [ 35659 ] {cb8bfbb4-4f45-4616-bd22-412e869e4e64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:33.931156 [ 35659 ] {418723e0-472d-4e24-b90d-111ddbc2979b} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT query_id(NULL, NULL);) 2025.06.18 11:21:33.934812 [ 35659 ] {418723e0-472d-4e24-b90d-111ddbc2979b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:33.961115 [ 35659 ] {6fc20d29-50d7-4447-bc20-7298549afd38} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT radians(NULL, NULL);) 2025.06.18 11:21:33.964727 [ 35659 ] {6fc20d29-50d7-4447-bc20-7298549afd38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:33.991232 [ 35659 ] {fa1145aa-ebc3-4157-b802-70859986731a} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rand(NULL, NULL);) 2025.06.18 11:21:33.994948 [ 35659 ] {fa1145aa-ebc3-4157-b802-70859986731a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:34.020385 [ 35659 ] {0f524b2c-c02c-4a44-8d19-a61a4dba4c6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rand32(NULL, NULL);) 2025.06.18 11:21:34.023919 [ 35659 ] {0f524b2c-c02c-4a44-8d19-a61a4dba4c6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:34.049606 [ 35659 ] {2867e8e9-93c6-4e5f-973d-6025be90c1b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rand64(NULL, NULL);) 2025.06.18 11:21:34.053326 [ 35659 ] {2867e8e9-93c6-4e5f-973d-6025be90c1b3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:34.203461 [ 35659 ] {5503dace-41b2-4a9f-a270-817702e81358} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randCanonical(NULL, NULL);) 2025.06.18 11:21:34.207417 [ 35659 ] {5503dace-41b2-4a9f-a270-817702e81358} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:34.285440 [ 35659 ] {28ad4c68-2dc9-4fe5-bd79-8ed91a615088} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randConstant(NULL, NULL);) 2025.06.18 11:21:34.289181 [ 35659 ] {28ad4c68-2dc9-4fe5-bd79-8ed91a615088} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:34.760474 [ 35659 ] {b3c597c3-5bd2-4c41-bd52-39fbba563c5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randomFixedString(NULL, NULL);) 2025.06.18 11:21:34.764410 [ 35659 ] {b3c597c3-5bd2-4c41-bd52-39fbba563c5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:34.899159 [ 35659 ] {348aaf34-bc0b-4612-ab86-c302a66a7fdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randomStringUTF8(NULL, NULL);) 2025.06.18 11:21:34.902944 [ 35659 ] {348aaf34-bc0b-4612-ab86-c302a66a7fdd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:35.013916 [ 35659 ] {978a3a39-54e9-45a2-8ec1-20eb532279d5} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rank(NULL, NULL);) 2025.06.18 11:21:35.021714 [ 35659 ] {978a3a39-54e9-45a2-8ec1-20eb532279d5} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:35.126998 [ 35659 ] {20d533b0-ca2d-47cf-b260-5c573fa515ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTLineString(NULL, NULL);) 2025.06.18 11:21:35.131279 [ 35659 ] {20d533b0-ca2d-47cf-b260-5c573fa515ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:35.159739 [ 35659 ] {1acb7762-5751-414c-8e9a-9d88339e1922} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTMultiLineString(NULL, NULL);) 2025.06.18 11:21:35.163974 [ 35659 ] {1acb7762-5751-414c-8e9a-9d88339e1922} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:35.193140 [ 35659 ] {c4a06a9d-261a-45c4-afa5-7c8813bab1ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTMultiPolygon(NULL, NULL);) 2025.06.18 11:21:35.197257 [ 35659 ] {c4a06a9d-261a-45c4-afa5-7c8813bab1ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:35.241896 [ 35659 ] {5eff3113-422d-4804-8eae-899815d3eaca} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTPoint(NULL, NULL);) 2025.06.18 11:21:35.249531 [ 35659 ] {5eff3113-422d-4804-8eae-899815d3eaca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:35.284715 [ 35659 ] {dc795601-cce1-4d6a-8e62-b58119d0d601} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTPolygon(NULL, NULL);) 2025.06.18 11:21:35.290048 [ 35659 ] {dc795601-cce1-4d6a-8e62-b58119d0d601} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:35.320542 [ 35659 ] {f00a32c6-db80-4c99-89f5-6012733fe633} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTRing(NULL, NULL);) 2025.06.18 11:21:35.325610 [ 35659 ] {f00a32c6-db80-4c99-89f5-6012733fe633} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:35.401747 [ 35659 ] {4e2f556d-4324-4c72-a915-ef1127137909} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT regexpQuoteMeta(NULL, NULL);) 2025.06.18 11:21:35.405667 [ 35659 ] {4e2f556d-4324-4c72-a915-ef1127137909} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.055027 [ 35659 ] {31a48ca5-15de-4212-a624-70ab4c0dd314} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsDate(NULL, NULL);) 2025.06.18 11:21:36.059385 [ 35659 ] {31a48ca5-15de-4212-a624-70ab4c0dd314} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.087222 [ 35659 ] {6b59b0b4-19da-4aba-8adb-8f6202141c1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsDateTime(NULL, NULL);) 2025.06.18 11:21:36.091550 [ 35659 ] {6b59b0b4-19da-4aba-8adb-8f6202141c1a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.119014 [ 35659 ] {10716ea0-3bf9-4bd1-bba4-72250f8cd47f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsFixedString(NULL, NULL);) 2025.06.18 11:21:36.122807 [ 35659 ] {10716ea0-3bf9-4bd1-bba4-72250f8cd47f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.150386 [ 35659 ] {92c91911-7be6-4780-98de-ce11292da4be} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsFloat32(NULL, NULL);) 2025.06.18 11:21:36.154218 [ 35659 ] {92c91911-7be6-4780-98de-ce11292da4be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.180647 [ 35659 ] {d828180a-f1e3-49a0-b0f1-93384ca5fa86} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsFloat64(NULL, NULL);) 2025.06.18 11:21:36.184577 [ 35659 ] {d828180a-f1e3-49a0-b0f1-93384ca5fa86} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.212135 [ 35659 ] {a3495ecc-75b9-4dcb-960b-55f97d8ac535} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt128(NULL, NULL);) 2025.06.18 11:21:36.215931 [ 35659 ] {a3495ecc-75b9-4dcb-960b-55f97d8ac535} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.245098 [ 35659 ] {f5175b4a-4409-4441-ae40-8fa5dee6966a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt16(NULL, NULL);) 2025.06.18 11:21:36.249530 [ 35659 ] {f5175b4a-4409-4441-ae40-8fa5dee6966a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.276166 [ 35659 ] {c8bce849-b294-4ee9-987b-f9f297dd084f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt256(NULL, NULL);) 2025.06.18 11:21:36.279878 [ 35659 ] {c8bce849-b294-4ee9-987b-f9f297dd084f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.307122 [ 35659 ] {22983d39-05a3-4812-9b60-0e44a7fe0cdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt32(NULL, NULL);) 2025.06.18 11:21:36.310982 [ 35659 ] {22983d39-05a3-4812-9b60-0e44a7fe0cdc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.338543 [ 35659 ] {e30f7a09-517c-4b8d-9392-bdf720c95578} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt64(NULL, NULL);) 2025.06.18 11:21:36.342466 [ 35659 ] {e30f7a09-517c-4b8d-9392-bdf720c95578} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.370713 [ 35659 ] {789f0069-680e-4dbe-9fac-6b8a5618c60d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt8(NULL, NULL);) 2025.06.18 11:21:36.374548 [ 35659 ] {789f0069-680e-4dbe-9fac-6b8a5618c60d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.402390 [ 35659 ] {da7cca72-e971-4de7-83ed-876b7e8bfa16} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsString(NULL, NULL);) 2025.06.18 11:21:36.406366 [ 35659 ] {da7cca72-e971-4de7-83ed-876b7e8bfa16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.434644 [ 35659 ] {fc250846-26bb-4339-ae03-fda7292505a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt128(NULL, NULL);) 2025.06.18 11:21:36.438506 [ 35659 ] {fc250846-26bb-4339-ae03-fda7292505a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.466244 [ 35659 ] {ce61546e-a915-453a-af7f-8844c18209d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt16(NULL, NULL);) 2025.06.18 11:21:36.470018 [ 35659 ] {ce61546e-a915-453a-af7f-8844c18209d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.497658 [ 35659 ] {f64f65fe-52e0-4bc6-93c4-c19fec5a3b92} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt256(NULL, NULL);) 2025.06.18 11:21:36.501726 [ 35659 ] {f64f65fe-52e0-4bc6-93c4-c19fec5a3b92} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.529562 [ 35659 ] {43677f64-f7b1-4924-93f9-c0b268b8efa5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt32(NULL, NULL);) 2025.06.18 11:21:36.533445 [ 35659 ] {43677f64-f7b1-4924-93f9-c0b268b8efa5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.561809 [ 35659 ] {d9e37a14-7030-46b1-8c79-12838bca2a39} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt64(NULL, NULL);) 2025.06.18 11:21:36.566302 [ 35659 ] {d9e37a14-7030-46b1-8c79-12838bca2a39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.594076 [ 35659 ] {5e30e1fd-eedb-4b5d-bfa7-62b5018079c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt8(NULL, NULL);) 2025.06.18 11:21:36.598063 [ 35659 ] {5e30e1fd-eedb-4b5d-bfa7-62b5018079c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.625663 [ 35659 ] {a0c1bd03-ac8c-4ae4-8dcc-dc1801e5cb25} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUUID(NULL, NULL);) 2025.06.18 11:21:36.629712 [ 35659 ] {a0c1bd03-ac8c-4ae4-8dcc-dc1801e5cb25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.711458 [ 35659 ] {91407d0e-cef8-49c5-bd88-c53104d31098} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replace(NULL, NULL);) 2025.06.18 11:21:36.715401 [ 35659 ] {91407d0e-cef8-49c5-bd88-c53104d31098} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.717457 [ 51841 ] {41b4ebca-1c13-4c4d-bc50-4af60831f104} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34394) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $$ab ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:36.720280 [ 51841 ] {41b4ebca-1c13-4c4d-bc50-4af60831f104} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:21:36.743481 [ 35659 ] {097cd281-76cd-4d43-8994-2d26b47231e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceAll(NULL, NULL);) 2025.06.18 11:21:36.747887 [ 35659 ] {097cd281-76cd-4d43-8994-2d26b47231e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.748354 [ 35674 ] {1a82cae2-3710-4cc3-b84e-296bbf6b40bb} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34406) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $$ ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:36.751542 [ 35674 ] {1a82cae2-3710-4cc3-b84e-296bbf6b40bb} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:21:36.774664 [ 35659 ] {efb68a26-03a7-4a3a-9c14-ff9bdb2fd555} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceOne(NULL, NULL);) 2025.06.18 11:21:36.778994 [ 35659 ] {efb68a26-03a7-4a3a-9c14-ff9bdb2fd555} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.779565 [ 35674 ] {f4912a6f-a040-4b16-8912-086c1dd21233} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34420) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $ ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:36.782851 [ 35674 ] {f4912a6f-a040-4b16-8912-086c1dd21233} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840653e 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d19404a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:21:36.806420 [ 35659 ] {a3cbb79a-f019-4142-9c1f-23a3785bc0a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceRegexpAll(NULL, NULL);) 2025.06.18 11:21:36.819600 [ 35659 ] {a3cbb79a-f019-4142-9c1f-23a3785bc0a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.847510 [ 35659 ] {a3bfd14b-6568-4845-8c82-b478f659d665} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceRegexpOne(NULL, NULL);) 2025.06.18 11:21:36.851520 [ 35659 ] {a3bfd14b-6568-4845-8c82-b478f659d665} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:36.880072 [ 35659 ] {bd12aad2-cfa9-4c4a-99a0-f52d895d180a} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replicate(NULL, NULL);) 2025.06.18 11:21:36.884428 [ 35659 ] {bd12aad2-cfa9-4c4a-99a0-f52d895d180a} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:36.985040 [ 35659 ] {39395112-c055-42bc-9ac9-a071486ff999} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reverse(NULL, NULL);) 2025.06.18 11:21:36.989008 [ 35659 ] {39395112-c055-42bc-9ac9-a071486ff999} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.018134 [ 35659 ] {e493c80e-76b3-4a21-aef7-316a87f02cce} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reverseUTF8(NULL, NULL);) 2025.06.18 11:21:37.022433 [ 35659 ] {e493c80e-76b3-4a21-aef7-316a87f02cce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.048043 [ 35659 ] {dae4da60-d53f-431a-acd6-a1cb13f0f612} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT revision(NULL, NULL);) 2025.06.18 11:21:37.051727 [ 35659 ] {dae4da60-d53f-431a-acd6-a1cb13f0f612} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.468510 [ 35659 ] {d6d7fdec-2638-47fe-93b8-592d0814a200} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT roundAge(NULL, NULL);) 2025.06.18 11:21:37.472649 [ 35659 ] {d6d7fdec-2638-47fe-93b8-592d0814a200} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.603846 [ 35659 ] {e493b788-2aa4-43e7-a018-b6ff1590e911} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT roundDuration(NULL, NULL);) 2025.06.18 11:21:37.607572 [ 35659 ] {e493b788-2aa4-43e7-a018-b6ff1590e911} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.634775 [ 35659 ] {020e44c0-b130-464d-95f0-698f424dc759} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT roundToExp2(NULL, NULL);) 2025.06.18 11:21:37.638833 [ 35659 ] {020e44c0-b130-464d-95f0-698f424dc759} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.664860 [ 35659 ] {3b4fbb7d-35a8-4181-92cc-3501fc501212} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rowNumberInAllBlocks(NULL, NULL);) 2025.06.18 11:21:37.668686 [ 35659 ] {3b4fbb7d-35a8-4181-92cc-3501fc501212} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.696212 [ 35659 ] {e196b605-1b5b-4d34-bb21-e65f5aa42cee} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rowNumberInBlock(NULL, NULL);) 2025.06.18 11:21:37.700163 [ 35659 ] {e196b605-1b5b-4d34-bb21-e65f5aa42cee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.761189 [ 35659 ] {dc23322e-4faa-4016-b143-1e89a2ddff0f} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT row_number(NULL, NULL);) 2025.06.18 11:21:37.767222 [ 35659 ] {dc23322e-4faa-4016-b143-1e89a2ddff0f} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:21:37.859644 [ 35659 ] {3b047362-ff58-4b40-91b4-c0d4cfec3b44} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningAccumulate(NULL, NULL);) 2025.06.18 11:21:37.863631 [ 35659 ] {3b047362-ff58-4b40-91b4-c0d4cfec3b44} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:21:37.889598 [ 35659 ] {91af3ebc-9f59-438b-8827-dea4fcff90d7} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningConcurrency(NULL, NULL);) 2025.06.18 11:21:37.893394 [ 35659 ] {91af3ebc-9f59-438b-8827-dea4fcff90d7} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:37.920013 [ 35659 ] {bf9f3452-3904-4160-a83e-6d9d9f2bafc6} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningDifference(NULL, NULL);) 2025.06.18 11:21:37.923803 [ 35659 ] {bf9f3452-3904-4160-a83e-6d9d9f2bafc6} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:21:37.949367 [ 35659 ] {fa7987dc-27ee-486a-a3f2-c06feaf6d8aa} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL);) 2025.06.18 11:21:37.953372 [ 35659 ] {fa7987dc-27ee-486a-a3f2-c06feaf6d8aa} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:21:37.980323 [ 35659 ] {ca80ea21-71a8-45ff-8a53-b2f25c821591} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2CapContains(NULL, NULL);) 2025.06.18 11:21:37.984377 [ 35659 ] {ca80ea21-71a8-45ff-8a53-b2f25c821591} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:37.986804 [ 612 ] {322426cc-a04b-4f9a-a08c-bba823ae626e} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:46056). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46056) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083d8ce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x00000000327894f5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b08d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b350 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7c06b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:37.990129 [ 612 ] {322426cc-a04b-4f9a-a08c-bba823ae626e} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:46056). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083d8ce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x00000000327894f5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b08d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b350 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7c06b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:37.990912 [ 612 ] {322426cc-a04b-4f9a-a08c-bba823ae626e} TCPHandler: Client has gone away. 2025.06.18 11:21:38.011704 [ 35659 ] {a9fc8b78-c417-4231-a037-30695e4e4384} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2CapUnion(NULL, NULL);) 2025.06.18 11:21:38.015610 [ 35659 ] {a9fc8b78-c417-4231-a037-30695e4e4384} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.098963 [ 35659 ] {96d88d19-3803-4f10-96d4-ed1753fb3258} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2GetNeighbors(NULL, NULL);) 2025.06.18 11:21:38.103421 [ 35659 ] {96d88d19-3803-4f10-96d4-ed1753fb3258} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.131545 [ 35659 ] {4c7795cd-b9b5-4b6a-b4b9-e660122530af} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectAdd(NULL, NULL);) 2025.06.18 11:21:38.135670 [ 35659 ] {4c7795cd-b9b5-4b6a-b4b9-e660122530af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.161673 [ 35659 ] {8fea1b6a-c323-49c2-9142-bce451fe1909} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectContains(NULL, NULL);) 2025.06.18 11:21:38.165290 [ 35659 ] {8fea1b6a-c323-49c2-9142-bce451fe1909} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.191536 [ 35659 ] {9178fac6-3875-4039-bd1e-b5aabc3640db} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectIntersection(NULL, NULL);) 2025.06.18 11:21:38.195477 [ 35659 ] {9178fac6-3875-4039-bd1e-b5aabc3640db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.218327 [ 35659 ] {7da15f48-321d-4ccf-a04e-6678216995ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectUnion(NULL, NULL);) 2025.06.18 11:21:38.221894 [ 35659 ] {7da15f48-321d-4ccf-a04e-6678216995ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.246247 [ 35659 ] {4d7549ff-008d-4154-94d9-771204e43821} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2ToGeo(NULL, NULL);) 2025.06.18 11:21:38.249893 [ 35659 ] {4d7549ff-008d-4154-94d9-771204e43821} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.468590 [ 35659 ] {0f0f0ddd-cef2-4ed8-9ba0-a3e47efcf42e} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sequenceNextNode(NULL, NULL);) 2025.06.18 11:21:38.472139 [ 35659 ] {0f0f0ddd-cef2-4ed8-9ba0-a3e47efcf42e} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.18 11:21:38.595186 [ 35659 ] {52a5696f-d0fe-4741-9105-bd52d2562426} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL);) 2025.06.18 11:21:38.599201 [ 35659 ] {52a5696f-d0fe-4741-9105-bd52d2562426} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.624242 [ 35659 ] {97926207-3f80-475c-9589-a99eea40086d} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT serverTimeZone(NULL, NULL);) 2025.06.18 11:21:38.628658 [ 35659 ] {97926207-3f80-475c-9589-a99eea40086d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.655177 [ 35659 ] {f9e81c4d-d815-4d38-af61-b6a1eaf767c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT serverTimezone(NULL, NULL);) 2025.06.18 11:21:38.658796 [ 35659 ] {f9e81c4d-d815-4d38-af61-b6a1eaf767c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.684205 [ 35659 ] {2acdcb58-aa64-4b15-b63e-ba23e63e9375} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT serverUUID(NULL, NULL);) 2025.06.18 11:21:38.687602 [ 35659 ] {2acdcb58-aa64-4b15-b63e-ba23e63e9375} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.712405 [ 35659 ] {a347724c-785b-4b30-a365-3e118bea5af0} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT shardCount(NULL, NULL);) 2025.06.18 11:21:38.715830 [ 35659 ] {a347724c-785b-4b30-a365-3e118bea5af0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.739635 [ 35659 ] {4f35ef60-0d83-47f3-ab5e-d695a1bf34a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT shardNum(NULL, NULL);) 2025.06.18 11:21:38.743031 [ 35659 ] {4f35ef60-0d83-47f3-ab5e-d695a1bf34a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.767938 [ 35659 ] {7a02b221-62f0-46cf-875a-b8aa9818a198} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT showCertificate(NULL, NULL);) 2025.06.18 11:21:38.772078 [ 35659 ] {7a02b221-62f0-46cf-875a-b8aa9818a198} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.797279 [ 35659 ] {afe9d273-7f9d-4ba3-8079-eb7dc8dcff67} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sigmoid(NULL, NULL);) 2025.06.18 11:21:38.801146 [ 35659 ] {afe9d273-7f9d-4ba3-8079-eb7dc8dcff67} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:38.827271 [ 35659 ] {3769ba80-861d-415f-a107-5dd8ba31048d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sign(NULL, NULL);) 2025.06.18 11:21:38.831075 [ 35659 ] {3769ba80-861d-415f-a107-5dd8ba31048d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:39.296024 [ 35659 ] {ede652e3-3424-48ae-8947-c5c5e2bec739} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sin(NULL, NULL);) 2025.06.18 11:21:39.299917 [ 35659 ] {ede652e3-3424-48ae-8947-c5c5e2bec739} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:39.391672 [ 35659 ] {367ea297-33fe-43b4-b985-fb8a6c9e8bc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sinh(NULL, NULL);) 2025.06.18 11:21:39.395297 [ 35659 ] {367ea297-33fe-43b4-b985-fb8a6c9e8bc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:39.866938 [ 35659 ] {f7fd40bd-db0f-4d41-bac8-ccde1a51b3d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sleep(NULL, NULL);) 2025.06.18 11:21:39.870772 [ 35659 ] {f7fd40bd-db0f-4d41-bac8-ccde1a51b3d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:39.896585 [ 35659 ] {2ff6f81f-770a-4237-9523-313513322c8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sleepEachRow(NULL, NULL);) 2025.06.18 11:21:39.900300 [ 35659 ] {2ff6f81f-770a-4237-9523-313513322c8f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:40.427895 [ 35659 ] {c348c881-f865-4469-a7b2-e2c780a7446b} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT soundex(NULL, NULL);) 2025.06.18 11:21:40.432590 [ 35659 ] {c348c881-f865-4469-a7b2-e2c780a7446b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:40.462566 [ 35659 ] {e739c077-ab94-42d3-b494-47f7b096567f} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT space(NULL, NULL);) 2025.06.18 11:21:40.466699 [ 35659 ] {e739c077-ab94-42d3-b494-47f7b096567f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:40.825465 [ 35669 ] {df16630e-43df-4daa-a0f9-63c55c6f9971} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:46112). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46112) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083d8ce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x00000000327894f5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b08d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b350 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7c06b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:40.828734 [ 35669 ] {df16630e-43df-4daa-a0f9-63c55c6f9971} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:46112). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083d8ce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x00000000327894f5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b08d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b350 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7c06b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:40.829488 [ 35669 ] {df16630e-43df-4daa-a0f9-63c55c6f9971} TCPHandler: Client has gone away. 2025.06.18 11:21:41.180587 [ 35659 ] {8b7fd1d9-26b2-461e-8473-642f9cb0b7e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sqidDecode(NULL, NULL);) 2025.06.18 11:21:41.222746 [ 35659 ] {8b7fd1d9-26b2-461e-8473-642f9cb0b7e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:41.304456 [ 35659 ] {6adbba10-066b-48e7-8fb9-137ffc57bcc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sqrt(NULL, NULL);) 2025.06.18 11:21:41.308188 [ 35659 ] {6adbba10-066b-48e7-8fb9-137ffc57bcc1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:41.715814 [ 35659 ] {f3f2d8a8-7d77-4999-a43a-9cf06a971cae} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT stem(NULL, NULL);) 2025.06.18 11:21:41.720715 [ 35659 ] {f3f2d8a8-7d77-4999-a43a-9cf06a971cae} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:42.142629 [ 35659 ] {b57588ba-c8b6-48d0-9042-b11f03da7106} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT stringToH3(NULL, NULL);) 2025.06.18 11:21:42.146632 [ 35659 ] {b57588ba-c8b6-48d0-9042-b11f03da7106} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:42.178057 [ 35659 ] {edcbf653-07da-461f-a764-9340f1ccec49} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT structureToCapnProtoSchema(NULL, NULL);) 2025.06.18 11:21:42.182486 [ 35659 ] {edcbf653-07da-461f-a764-9340f1ccec49} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:42.210684 [ 35659 ] {9f04e4fe-a992-430e-964c-d195d905e9d6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT structureToProtobufSchema(NULL, NULL);) 2025.06.18 11:21:42.214633 [ 35659 ] {9f04e4fe-a992-430e-964c-d195d905e9d6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:42.325554 [ 35659 ] {853585ff-e265-4c59-b547-9ed5d1aecb13} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT subBitmap(NULL, NULL);) 2025.06.18 11:21:42.329510 [ 35659 ] {853585ff-e265-4c59-b547-9ed5d1aecb13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:42.525403 [ 35659 ] {10fcc5a8-bb48-4a63-8bf5-00cf98d45d76} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT substringIndex(NULL, NULL);) 2025.06.18 11:21:42.529045 [ 35659 ] {10fcc5a8-bb48-4a63-8bf5-00cf98d45d76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:42.554396 [ 35659 ] {11336389-81aa-4a02-add8-cd23eab74a6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT substringIndexUTF8(NULL, NULL);) 2025.06.18 11:21:42.558298 [ 35659 ] {11336389-81aa-4a02-add8-cd23eab74a6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:42.808805 [ 51854 ] {4e04da79-ba68-4bee-926b-edb2a9c0aafa} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47952) (comment: 02006_client_test_hint_error_name.sql) (in query: select throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:42.811763 [ 51854 ] {4e04da79-ba68-4bee-926b-edb2a9c0aafa} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:43.486579 [ 36000 ] {e665c6b1-64b5-45bd-9d34-3cc62221e284} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:46158). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46158) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083d8ce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x00000000327894f5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b08d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b350 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7c06b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:43.489900 [ 36000 ] {e665c6b1-64b5-45bd-9d34-3cc62221e284} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:46158). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c3f80 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083d8ce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x00000000327894f5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b08d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b350 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7c06b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:43.490651 [ 36000 ] {e665c6b1-64b5-45bd-9d34-3cc62221e284} TCPHandler: Client has gone away. 2025.06.18 11:21:44.060874 [ 35659 ] {8bdd37d8-9bd3-4421-98c4-06fcdde49587} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT synonyms(NULL, NULL);) 2025.06.18 11:21:44.064666 [ 35659 ] {8bdd37d8-9bd3-4421-98c4-06fcdde49587} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:21:44.089388 [ 35659 ] {0eee4439-720b-42b7-8690-041a50c38dc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tan(NULL, NULL);) 2025.06.18 11:21:44.093138 [ 35659 ] {0eee4439-720b-42b7-8690-041a50c38dc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.118356 [ 35659 ] {3e5545d2-583c-4a35-9c1c-2dd4b3b655bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tanh(NULL, NULL);) 2025.06.18 11:21:44.122023 [ 35659 ] {3e5545d2-583c-4a35-9c1c-2dd4b3b655bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.146773 [ 35659 ] {ae0de1cd-83e1-49a3-94c8-cea006f9331f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tcpPort(NULL, NULL);) 2025.06.18 11:21:44.150462 [ 35659 ] {ae0de1cd-83e1-49a3-94c8-cea006f9331f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.175740 [ 35659 ] {4df144de-34e7-4ae0-a5fc-feb8762aabee} executeQuery: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT test_function(NULL, NULL);) 2025.06.18 11:21:44.179461 [ 35659 ] {4df144de-34e7-4ae0-a5fc-feb8762aabee} TCPHandler: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) 2025.06.18 11:21:44.204771 [ 35659 ] {12c49ea5-56fc-4343-99c3-0a4fadc4587e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tgamma(NULL, NULL);) 2025.06.18 11:21:44.208338 [ 35659 ] {12c49ea5-56fc-4343-99c3-0a4fadc4587e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.356065 [ 35659 ] {5f7039e3-4db4-4559-b2e9-ff1db70b24ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tid(NULL, NULL);) 2025.06.18 11:21:44.360089 [ 35659 ] {5f7039e3-4db4-4559-b2e9-ff1db70b24ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.544710 [ 35659 ] {b2cb8add-444f-42a5-a10d-fd6262839aeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timeZone(NULL, NULL);) 2025.06.18 11:21:44.548551 [ 35659 ] {b2cb8add-444f-42a5-a10d-fd6262839aeb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.574373 [ 35659 ] {711b23d1-a8f3-4e71-b6eb-4b350bd0591d} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timeZoneOf(NULL, NULL);) 2025.06.18 11:21:44.578271 [ 35659 ] {711b23d1-a8f3-4e71-b6eb-4b350bd0591d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.822231 [ 35659 ] {25cd2adb-590b-43eb-a3b4-879046135f40} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timezone(NULL, NULL);) 2025.06.18 11:21:44.825875 [ 35659 ] {25cd2adb-590b-43eb-a3b4-879046135f40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.849904 [ 35659 ] {dcbae956-57b4-44ff-bf18-e627c3da8d48} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timezoneOf(NULL, NULL);) 2025.06.18 11:21:44.853546 [ 35659 ] {dcbae956-57b4-44ff-bf18-e627c3da8d48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.929696 [ 35659 ] {9472a114-2aa5-4f64-a0c5-19c26aeae195} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toBool(NULL, NULL);) 2025.06.18 11:21:44.933419 [ 35659 ] {9472a114-2aa5-4f64-a0c5-19c26aeae195} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:44.957092 [ 35659 ] {67a10282-ca7f-43ee-8c24-d34e3e53c87e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toColumnTypeName(NULL, NULL);) 2025.06.18 11:21:44.960695 [ 35659 ] {67a10282-ca7f-43ee-8c24-d34e3e53c87e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:45.094246 [ 35659 ] {f36ad8e9-7c38-4487-8347-c65cfd397610} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDate32OrDefault(NULL, NULL);) 2025.06.18 11:21:45.097911 [ 35659 ] {f36ad8e9-7c38-4487-8347-c65cfd397610} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:45.222230 [ 35659 ] {d294affe-d851-4f98-b1b3-b59a7f15bd8d} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDateOrDefault(NULL, NULL);) 2025.06.18 11:21:45.226070 [ 35659 ] {d294affe-d851-4f98-b1b3-b59a7f15bd8d} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:45.512836 [ 35659 ] {299682df-9a8f-4346-a4b2-2539bc77e21b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDateTime64OrDefault(NULL, NULL);) 2025.06.18 11:21:45.516703 [ 35659 ] {299682df-9a8f-4346-a4b2-2539bc77e21b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:45.660400 [ 35659 ] {b86377bf-f907-4a8a-8b44-6bf5ee7a05c2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDateTimeOrDefault(NULL, NULL);) 2025.06.18 11:21:45.664343 [ 35659 ] {b86377bf-f907-4a8a-8b44-6bf5ee7a05c2} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:46.078657 [ 35659 ] {502229fb-9842-402e-8468-ea1d8a18c3a3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal128OrDefault(NULL, NULL);) 2025.06.18 11:21:46.083430 [ 35659 ] {502229fb-9842-402e-8468-ea1d8a18c3a3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:46.295955 [ 35659 ] {a8d770ea-84c5-438a-8c7d-ff06993b718a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal256OrDefault(NULL, NULL);) 2025.06.18 11:21:46.300319 [ 35659 ] {a8d770ea-84c5-438a-8c7d-ff06993b718a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:46.485978 [ 35659 ] {59f711b5-f646-49de-95a5-01261a657de0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal32OrDefault(NULL, NULL);) 2025.06.18 11:21:46.489947 [ 35659 ] {59f711b5-f646-49de-95a5-01261a657de0} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:46.673449 [ 35659 ] {c821a4c1-4d73-487e-89e0-81f38dda49be} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal64OrDefault(NULL, NULL);) 2025.06.18 11:21:46.677486 [ 35659 ] {c821a4c1-4d73-487e-89e0-81f38dda49be} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:46.972724 [ 35659 ] {7092ac20-e02d-45b7-bd52-e6fe3f9d5b61} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toFloat32OrDefault(NULL, NULL);) 2025.06.18 11:21:46.976730 [ 35659 ] {7092ac20-e02d-45b7-bd52-e6fe3f9d5b61} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:47.173916 [ 35659 ] {a23fc630-6b8e-4e98-a3cb-d200ccc3f29d} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toFloat64OrDefault(NULL, NULL);) 2025.06.18 11:21:47.178708 [ 35659 ] {a23fc630-6b8e-4e98-a3cb-d200ccc3f29d} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:47.457233 [ 35659 ] {672c25a9-7ff6-4f13-a4fa-2305412058cc} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toIPv4OrDefault(NULL, NULL);) 2025.06.18 11:21:47.461223 [ 35659 ] {672c25a9-7ff6-4f13-a4fa-2305412058cc} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:47.692675 [ 35659 ] {70f6455c-fe9d-4bee-833b-0f12f73c59d9} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toIPv6OrDefault(NULL, NULL);) 2025.06.18 11:21:47.697889 [ 35659 ] {70f6455c-fe9d-4bee-833b-0f12f73c59d9} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:48.071448 [ 35659 ] {b593455a-eb45-4c22-94f1-d34e268ba464} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt128OrDefault(NULL, NULL);) 2025.06.18 11:21:48.075249 [ 35659 ] {b593455a-eb45-4c22-94f1-d34e268ba464} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:48.263093 [ 35659 ] {11f3a002-b6da-453e-af04-7a8f65ae1dee} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt16OrDefault(NULL, NULL);) 2025.06.18 11:21:48.266871 [ 35659 ] {11f3a002-b6da-453e-af04-7a8f65ae1dee} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:48.449055 [ 35659 ] {aab5c7de-ce0b-4b64-982f-97d67f4ea89b} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt256OrDefault(NULL, NULL);) 2025.06.18 11:21:48.452949 [ 35659 ] {aab5c7de-ce0b-4b64-982f-97d67f4ea89b} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:48.662056 [ 35659 ] {ab68bda0-de3a-4eaf-a2dc-12fa01962c49} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt32OrDefault(NULL, NULL);) 2025.06.18 11:21:48.666257 [ 35659 ] {ab68bda0-de3a-4eaf-a2dc-12fa01962c49} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:48.674528 [ 51854 ] {adf59ce5-1c37-4a74-85cd-dd0e280c6cb6} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48070) (comment: 01412_group_array_moving_shard.sql) (in query: SELECT groupArrayMovingSum(0)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:274: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34ea57 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:48.677886 [ 51854 ] {adf59ce5-1c37-4a74-85cd-dd0e280c6cb6} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:274: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34ea57 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:48.849415 [ 35659 ] {a6cebed7-e481-456d-8f24-875719d5efc0} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt64OrDefault(NULL, NULL);) 2025.06.18 11:21:48.854123 [ 35659 ] {a6cebed7-e481-456d-8f24-875719d5efc0} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:49.031574 [ 35659 ] {ef18a173-a1d0-4989-8118-5f241149570d} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt8OrDefault(NULL, NULL);) 2025.06.18 11:21:49.035445 [ 35659 ] {ef18a173-a1d0-4989-8118-5f241149570d} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:49.370042 [ 51854 ] {a4acd9b4-2d8d-4aec-8fbe-b5a901060701} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48070) (comment: 01412_group_array_moving_shard.sql) (in query: SELECT groupArrayMovingSum(0.)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:270: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34f830 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:49.372823 [ 51854 ] {a4acd9b4-2d8d-4aec-8fbe-b5a901060701} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:270: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34f830 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:49.404218 [ 51854 ] {f867facc-6196-4d56-8232-1d47bea66ef8} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48070) (comment: 01412_group_array_moving_shard.sql) (in query: SELECT groupArrayMovingSum(0.1)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:270: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34f830 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:49.406548 [ 51854 ] {f867facc-6196-4d56-8232-1d47bea66ef8} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:270: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34f830 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:49.448783 [ 51854 ] {6ccce5af-7765-48e5-9e74-964f900b596f} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48070) (comment: 01412_group_array_moving_shard.sql) (in query: SELECT groupArrayMovingSum(0.1)(1) FROM remote('127.0.0.{1,2}', numbers(100));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:270: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34f830 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:49.452077 [ 51854 ] {6ccce5af-7765-48e5-9e74-964f900b596f} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:270: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f34f830 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:21:49.785317 [ 35659 ] {18f1c23d-2cfc-456e-b157-60437f3fa335} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toJSONString(NULL, NULL);) 2025.06.18 11:21:49.788799 [ 35659 ] {18f1c23d-2cfc-456e-b157-60437f3fa335} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:49.907944 [ 35659 ] {c4c6b273-0123-496a-9f8e-c6074318cc3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toLowCardinality(NULL, NULL);) 2025.06.18 11:21:49.911620 [ 35659 ] {c4c6b273-0123-496a-9f8e-c6074318cc3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:50.035482 [ 35659 ] {c693d459-39e6-4ad3-8f2c-fb07513f470d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toModifiedJulianDay(NULL, NULL);) 2025.06.18 11:21:50.039220 [ 35659 ] {c693d459-39e6-4ad3-8f2c-fb07513f470d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:50.063282 [ 35659 ] {23c9cabb-2cb2-4b40-b23e-0fef4448cbed} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL);) 2025.06.18 11:21:50.067217 [ 35659 ] {23c9cabb-2cb2-4b40-b23e-0fef4448cbed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:50.197193 [ 35659 ] {51c35e30-ce37-415e-bdb8-2f85aa76fa71} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toNullable(NULL, NULL);) 2025.06.18 11:21:50.201516 [ 35659 ] {51c35e30-ce37-415e-bdb8-2f85aa76fa71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:51.055588 [ 51854 ] {9044d865-2c8a-43e6-a544-6ebb2af44ae7} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48070) (comment: 01412_group_array_moving_shard.sql) (in query: SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS7_9FieldTypeEjjRNS8_9FieldTypeE @ 0x00000000324d9ebb 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIjEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x00000000324fe60e 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fb024 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:21:51.058179 [ 51854 ] {9044d865-2c8a-43e6-a544-6ebb2af44ae7} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS7_9FieldTypeEjjRNS8_9FieldTypeE @ 0x00000000324d9ebb 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIjEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x00000000324fe60e 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fb024 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c6c3f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:21:51.761180 [ 35659 ] {364b0980-45e2-47be-9c25-9edfe1a985d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toStringCutToZero(NULL, NULL);) 2025.06.18 11:21:51.764828 [ 35659 ] {364b0980-45e2-47be-9c25-9edfe1a985d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:51.952433 [ 35659 ] {e3b9f210-0fe7-4d8f-b1c6-06831d9fc9a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toTypeName(NULL, NULL);) 2025.06.18 11:21:51.958625 [ 35659 ] {e3b9f210-0fe7-4d8f-b1c6-06831d9fc9a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:52.033349 [ 35659 ] {6cc08acf-2c75-495a-b3ef-b273498797bc} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt128OrDefault(NULL, NULL);) 2025.06.18 11:21:52.038219 [ 35659 ] {6cc08acf-2c75-495a-b3ef-b273498797bc} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:52.218274 [ 35659 ] {2fc49240-f763-4df3-a2c0-02482915f0a8} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt16OrDefault(NULL, NULL);) 2025.06.18 11:21:52.221821 [ 35659 ] {2fc49240-f763-4df3-a2c0-02482915f0a8} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:52.389641 [ 35659 ] {625e976d-e6ca-48da-9517-0f61f1a71dea} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt256OrDefault(NULL, NULL);) 2025.06.18 11:21:52.394507 [ 35659 ] {625e976d-e6ca-48da-9517-0f61f1a71dea} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:52.567433 [ 35659 ] {08e2e7e5-6e74-450f-8d6b-84c37e610a98} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt32OrDefault(NULL, NULL);) 2025.06.18 11:21:52.571376 [ 35659 ] {08e2e7e5-6e74-450f-8d6b-84c37e610a98} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:52.748103 [ 35659 ] {b9d3d979-7c5b-41c4-990d-51216759a150} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt64OrDefault(NULL, NULL);) 2025.06.18 11:21:52.751954 [ 35659 ] {b9d3d979-7c5b-41c4-990d-51216759a150} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:52.920460 [ 35659 ] {51beeb68-b0b9-4d60-90c5-107dbb28e25c} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt8OrDefault(NULL, NULL);) 2025.06.18 11:21:52.924095 [ 35659 ] {51beeb68-b0b9-4d60-90c5-107dbb28e25c} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:53.145473 [ 35659 ] {d1455dbb-c369-4aff-a1c5-cce1f29e19b6} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUUIDOrDefault(NULL, NULL);) 2025.06.18 11:21:53.149084 [ 35659 ] {d1455dbb-c369-4aff-a1c5-cce1f29e19b6} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.18 11:21:53.321195 [ 35659 ] {7bcbe99c-6431-47bd-a0d4-c94ef7d25292} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL);) 2025.06.18 11:21:53.324785 [ 35659 ] {7bcbe99c-6431-47bd-a0d4-c94ef7d25292} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:53.348414 [ 35659 ] {b613a8f8-2dca-4350-9428-dd374d9d91d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL);) 2025.06.18 11:21:53.352308 [ 35659 ] {b613a8f8-2dca-4350-9428-dd374d9d91d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:53.374446 [ 35659 ] {4d68c1dc-4619-41a1-8d79-d55d643c25cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL);) 2025.06.18 11:21:53.378228 [ 35659 ] {4d68c1dc-4619-41a1-8d79-d55d643c25cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:53.402658 [ 35659 ] {74eef876-00d4-4a7b-98ce-e75d9e53f9a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toValidUTF8(NULL, NULL);) 2025.06.18 11:21:53.406291 [ 35659 ] {74eef876-00d4-4a7b-98ce-e75d9e53f9a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:53.797625 [ 35659 ] {d5788dfa-f017-4213-bbd8-059c3b1f1c81} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT today(NULL, NULL);) 2025.06.18 11:21:53.801870 [ 35659 ] {d5788dfa-f017-4213-bbd8-059c3b1f1c81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:53.829680 [ 35659 ] {a7957467-4659-4de2-b5de-68c810c04351} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tokens(NULL, NULL);) 2025.06.18 11:21:53.833768 [ 35659 ] {a7957467-4659-4de2-b5de-68c810c04351} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.004986 [ 35659 ] {9fd2a65d-9270-4810-aef4-a0d294870bdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT topLevelDomain(NULL, NULL);) 2025.06.18 11:21:54.009370 [ 35659 ] {9fd2a65d-9270-4810-aef4-a0d294870bdc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.035484 [ 35659 ] {981fe532-cbd4-4c36-8235-20f579acd576} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT topLevelDomainRFC(NULL, NULL);) 2025.06.18 11:21:54.039620 [ 35659 ] {981fe532-cbd4-4c36-8235-20f579acd576} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.066706 [ 35659 ] {b1f5975a-0f80-4e59-aabc-6d0651cbb376} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transactionID(NULL, NULL);) 2025.06.18 11:21:54.070658 [ 35659 ] {b1f5975a-0f80-4e59-aabc-6d0651cbb376} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.097099 [ 35659 ] {80dea604-3ce7-454a-a9db-bc88614750bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transactionLatestSnapshot(NULL, NULL);) 2025.06.18 11:21:54.101786 [ 35659 ] {80dea604-3ce7-454a-a9db-bc88614750bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.127504 [ 35659 ] {0d8c7e54-1046-4aa6-9229-2ebd8300fde3} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transactionOldestSnapshot(NULL, NULL);) 2025.06.18 11:21:54.131517 [ 35659 ] {0d8c7e54-1046-4aa6-9229-2ebd8300fde3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.156659 [ 35659 ] {00e79e6f-52a1-4894-b9ba-078a74443368} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transform(NULL, NULL);) 2025.06.18 11:21:54.160639 [ 35659 ] {00e79e6f-52a1-4894-b9ba-078a74443368} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.186380 [ 35659 ] {d820d5cd-3ac2-49d7-8d53-6e6adb6ef83c} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT translate(NULL, NULL);) 2025.06.18 11:21:54.190414 [ 35659 ] {d820d5cd-3ac2-49d7-8d53-6e6adb6ef83c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.216791 [ 35659 ] {3339889e-2789-4ff8-8686-cf1c9ad3ed85} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT translateUTF8(NULL, NULL);) 2025.06.18 11:21:54.220892 [ 35659 ] {3339889e-2789-4ff8-8686-cf1c9ad3ed85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.247830 [ 35659 ] {e748062e-fac9-4bb8-a3ee-5ff136b7c60f} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 2, should be 1: In scope SELECT trimBoth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT trimBoth(NULL, NULL);) 2025.06.18 11:21:54.251944 [ 35659 ] {e748062e-fac9-4bb8-a3ee-5ff136b7c60f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 2, should be 1: In scope SELECT trimBoth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.277243 [ 35659 ] {d3462af8-3c6d-40e7-bea8-192b496f1501} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 2, should be 1: In scope SELECT trimLeft(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT trimLeft(NULL, NULL);) 2025.06.18 11:21:54.281389 [ 35659 ] {d3462af8-3c6d-40e7-bea8-192b496f1501} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 2, should be 1: In scope SELECT trimLeft(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.306317 [ 35659 ] {53d793e5-c7f4-4f57-8167-7ec25a6dadd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 2, should be 1: In scope SELECT trimRight(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT trimRight(NULL, NULL);) 2025.06.18 11:21:54.310277 [ 35659 ] {53d793e5-c7f4-4f57-8167-7ec25a6dadd2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 2, should be 1: In scope SELECT trimRight(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.441450 [ 35659 ] {b167e64a-8245-4eae-9ed8-231267805bb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryBase58Decode(NULL, NULL);) 2025.06.18 11:21:54.445963 [ 35659 ] {b167e64a-8245-4eae-9ed8-231267805bb1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.475160 [ 35659 ] {d8349ecf-8c4e-4101-a07e-b73cc762d7c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryBase64Decode(NULL, NULL);) 2025.06.18 11:21:54.479426 [ 35659 ] {d8349ecf-8c4e-4101-a07e-b73cc762d7c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.509728 [ 35659 ] {2f7c6e57-11b8-4d61-93a7-71dfe4353678} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryBase64URLDecode(NULL, NULL);) 2025.06.18 11:21:54.514940 [ 35659 ] {2f7c6e57-11b8-4d61-93a7-71dfe4353678} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.607386 [ 35659 ] {0f0aada9-2122-4fdb-9885-ecb867cd033a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryIdnaEncode(NULL, NULL);) 2025.06.18 11:21:54.611947 [ 35659 ] {0f0aada9-2122-4fdb-9885-ecb867cd033a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:54.642008 [ 35659 ] {03b2d333-3e99-4159-bacb-06148ca07e18} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryPunycodeDecode(NULL, NULL);) 2025.06.18 11:21:54.660203 [ 35659 ] {03b2d333-3e99-4159-bacb-06148ca07e18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:55.096306 [ 35659 ] {75e3bce8-9f59-41d0-8ad7-7874b9c6a8bf} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleElement(NULL, NULL);) 2025.06.18 11:21:55.100375 [ 35659 ] {75e3bce8-9f59-41d0-8ad7-7874b9c6a8bf} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:55.660590 [ 35659 ] {38fcc043-5dea-4896-9d6a-754b0d2a4ff8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleNames(NULL, NULL);) 2025.06.18 11:21:55.664562 [ 35659 ] {38fcc043-5dea-4896-9d6a-754b0d2a4ff8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:55.693212 [ 35659 ] {3db1b489-fde7-4bc2-bfaa-83cb1bf4f15e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleNegate(NULL, NULL);) 2025.06.18 11:21:55.696972 [ 35659 ] {3db1b489-fde7-4bc2-bfaa-83cb1bf4f15e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:55.774784 [ 35659 ] {0ba9a39f-8e6a-4709-82d6-f59b09da68c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleToNameValuePairs(NULL, NULL);) 2025.06.18 11:21:55.778817 [ 35659 ] {0ba9a39f-8e6a-4709-82d6-f59b09da68c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:55.804983 [ 35659 ] {1860448a-69e7-4e3d-b99f-01262088e950} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ucase(NULL, NULL);) 2025.06.18 11:21:55.808863 [ 35659 ] {1860448a-69e7-4e3d-b99f-01262088e950} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:55.834247 [ 35659 ] {05ed19f7-2a4a-42f5-baf5-f64955f3d2a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT unbin(NULL, NULL);) 2025.06.18 11:21:55.838123 [ 35659 ] {05ed19f7-2a4a-42f5-baf5-f64955f3d2a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:55.861605 [ 35659 ] {2bb328f7-0f4d-4b70-8378-873ef5e399e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT unhex(NULL, NULL);) 2025.06.18 11:21:55.865356 [ 35659 ] {2bb328f7-0f4d-4b70-8378-873ef5e399e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:56.528253 [ 35659 ] {a8e10b6d-be26-4509-a27f-0cb0530f1511} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT upper(NULL, NULL);) 2025.06.18 11:21:56.532110 [ 35659 ] {a8e10b6d-be26-4509-a27f-0cb0530f1511} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:56.555461 [ 35659 ] {10b0be08-bde2-4c72-9e62-23c476b4d46d} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT upperUTF8(NULL, NULL);) 2025.06.18 11:21:56.559404 [ 35659 ] {10b0be08-bde2-4c72-9e62-23c476b4d46d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:56.584507 [ 35659 ] {136ad80c-6f20-4af6-83bd-929ccc8d04cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT uptime(NULL, NULL);) 2025.06.18 11:21:56.588309 [ 35659 ] {136ad80c-6f20-4af6-83bd-929ccc8d04cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:56.613191 [ 35659 ] {9b4d6d31-8dd6-44b8-bc04-1edfa8607cc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT user(NULL, NULL);) 2025.06.18 11:21:56.617095 [ 35659 ] {9b4d6d31-8dd6-44b8-bc04-1edfa8607cc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:56.958787 [ 35659 ] {1d861955-71fd-4a98-97ca-c8958fef0391} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT variantElement(NULL, NULL);) 2025.06.18 11:21:56.963162 [ 35659 ] {1d861955-71fd-4a98-97ca-c8958fef0391} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:21:56.989921 [ 35659 ] {4b318cb0-7335-4984-80ce-a16a7b35f10c} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT variantType(NULL, NULL);) 2025.06.18 11:21:56.994261 [ 35659 ] {4b318cb0-7335-4984-80ce-a16a7b35f10c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:57.125865 [ 1402 ] {77430f01-4ea6-42c8-a317-29c0dbee3609} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_9cjymizk.async_insert_landing SETTINGS wait_for_async_insert = 0, async_insert = 1 FORMAT Values' with query id cxcgwtlbif. DB::Exception: Cannot parse string 'Invalid' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION if(isNull(-dummy-0) : 3, defaultValueOfTypeName('UInt32') :: 2, _CAST(-dummy-0, 'UInt32') :: 4) -> if(isNull(-dummy-0), defaultValueOfTypeName('UInt32'), _CAST(-dummy-0, 'UInt32')) UInt32 : 1' 2025.06.18 11:21:57.132377 [ 35659 ] {0b200eed-a785-4f7d-ba57-4f6aa18a29a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT version(NULL, NULL);) 2025.06.18 11:21:57.136303 [ 35659 ] {0b200eed-a785-4f7d-ba57-4f6aa18a29a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:57.161603 [ 35659 ] {efede710-7c6f-42ed-8658-716d527f374f} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT visibleWidth(NULL, NULL);) 2025.06.18 11:21:57.166023 [ 35659 ] {efede710-7c6f-42ed-8658-716d527f374f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:57.701133 [ 35659 ] {f34e58a6-e19e-4328-af79-c05e9733eef3} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT widthBucket(NULL, NULL);) 2025.06.18 11:21:57.705114 [ 35659 ] {f34e58a6-e19e-4328-af79-c05e9733eef3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:57.726757 [ 35659 ] {d797bc50-168b-4875-8ab0-a161463d0257} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT width_bucket(NULL, NULL);) 2025.06.18 11:21:57.729998 [ 35659 ] {d797bc50-168b-4875-8ab0-a161463d0257} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:57.862211 [ 35659 ] {83084019-01ff-4341-bb5b-9d9c913b66d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT wkt(NULL, NULL);) 2025.06.18 11:21:57.865846 [ 35659 ] {83084019-01ff-4341-bb5b-9d9c913b66d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:58.941007 [ 35659 ] {f4e14326-26ab-4a8f-a012-872f2dc309f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT yesterday(NULL, NULL);) 2025.06.18 11:21:58.944674 [ 35659 ] {f4e14326-26ab-4a8f-a012-872f2dc309f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:21:58.967458 [ 35659 ] {35c32a0f-ed48-445f-aa9e-1730e9391178} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39946) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT zookeeperSessionUptime(NULL, NULL);) 2025.06.18 11:21:58.970970 [ 35659 ] {35c32a0f-ed48-445f-aa9e-1730e9391178} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:22:03.197646 [ 2704 ] {7955df76-3163-4213-a78d-6d1c4387996b} DistributedSink: Structure does not match (remote: key Nullable(UInt64) Nullable(size = 0, UInt64(size = 0), UInt8(size = 0)), local: key UInt64 UInt64(size = 1)), implicit conversion will be done. 2025.06.18 11:22:14.962527 [ 51889 ] {2faba1a7-4e5f-4b7c-8af2-7e9d7260e5a0} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37490) (comment: 02201_use_skip_indexes_if_final.sql) (in query: -- { echoOn } SELECT * FROM data_02201 FINAL WHERE value = 1 SETTINGS use_skip_indexes=0, use_skip_indexes_if_final=0, max_rows_to_read=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:14.969132 [ 51889 ] {2faba1a7-4e5f-4b7c-8af2-7e9d7260e5a0} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:15.034575 [ 51889 ] {83b89dd0-5f09-42b5-9733-b6d5be2cf81b} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37490) (comment: 02201_use_skip_indexes_if_final.sql) (in query: SELECT * FROM data_02201 FINAL WHERE value = 1 SETTINGS use_skip_indexes=1, use_skip_indexes_if_final=0, max_rows_to_read=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:15.037373 [ 51889 ] {83b89dd0-5f09-42b5-9733-b6d5be2cf81b} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:15.103149 [ 51889 ] {07d9de32-9dbd-47c4-a745-f9ef86bbaeff} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37490) (comment: 02201_use_skip_indexes_if_final.sql) (in query: SELECT * FROM data_02201 FINAL WHERE value = 1 SETTINGS use_skip_indexes=0, use_skip_indexes_if_final=1, max_rows_to_read=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:15.105948 [ 51889 ] {07d9de32-9dbd-47c4-a745-f9ef86bbaeff} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:16.394062 [ 51854 ] {f82cc03d-eade-4923-9578-80d105471ba6} executeQuery: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37494) (comment: 02294_dictionaries_hierarchical_index.sql) (in query: CREATE DICTIONARY hierarchy_flat_dictionary_index ( id UInt64, parent_id UInt64 BIDIRECTIONAL ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE 'test_hierarchy_source_table')) LAYOUT(FLAT()) LIFETIME(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x00000000306c8b78 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000306bdbb1 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:210: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000003478a3dc 7. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003824243f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003824fd2a 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003824fa23 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824b480 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:16.397361 [ 51854 ] {f82cc03d-eade-4923-9578-80d105471ba6} TCPHandler: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x00000000306c8b78 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000306bdbb1 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:210: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000003478a3dc 7. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003824243f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003824fd2a 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003824fa23 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824b480 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:21.685835 [ 35669 ] {4b26750f-625c-4642-b190-8444284aa290} BackupsWorker: Failed to make backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_2_bad.zip'): Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ZipArchiveReader::showError(String const&) const @ 0x0000000030a5e7c3 4. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x0000000030a6349f 5. ? @ 0x0000000030a652d0 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x0000000030a651d0 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x0000000030a5eb9f 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::BackupImpl::readBackupMetadata() @ 0x00000000318cad8d 9. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000031977e57 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 13. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 14. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 15. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x00000000319778ad 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 19. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 20. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 21. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 23. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:22:21.687732 [ 35669 ] {4b26750f-625c-4642-b190-8444284aa290} executeQuery: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37642) (comment: 02843_backup_use_same_password_for_base_backup.sh) (in query: BACKUP TABLE data TO Disk('backups', '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_2_bad.zip') SETTINGS base_backup=Disk('backups', '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_1.zip'),password='password'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ZipArchiveReader::showError(String const&) const @ 0x0000000030a5e7c3 4. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x0000000030a6349f 5. ? @ 0x0000000030a652d0 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x0000000030a651d0 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x0000000030a5eb9f 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::BackupImpl::readBackupMetadata() @ 0x00000000318cad8d 9. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000031977e57 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 13. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 14. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 15. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x00000000319778ad 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 19. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 20. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 21. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 23. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:22:21.691923 [ 35669 ] {4b26750f-625c-4642-b190-8444284aa290} TCPHandler: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ZipArchiveReader::showError(String const&) const @ 0x0000000030a5e7c3 4. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x0000000030a6349f 5. ? @ 0x0000000030a652d0 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x0000000030a651d0 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x0000000030a5eb9f 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::BackupImpl::readBackupMetadata() @ 0x00000000318cad8d 9. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000031977e57 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 13. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 14. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 15. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000318c3cce 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x00000000318c55c2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x00000000319778ad 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 19. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 20. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031719991 21. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170d758 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000003170b668 23. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a66298 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:22:24.096358 [ 51843 ] {c7fe8e8c-db8d-46fd-bcfd-7e896e8d7da3} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrZero(1.1, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009464b54 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:24.099541 [ 51843 ] {c7fe8e8c-db8d-46fd-bcfd-7e896e8d7da3} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009464b54 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:25.098385 [ 35674 ] {8f9cf2a4-c129-40c8-9e18-24d57fc08f79} executeQuery: Code: 6. DB::Exception: Cannot parse string '2021-1-01 00:00:00' as DateTime: syntax error at position 10 (parsed just '2021-1-01 '): In scope SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1')). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56728) (comment: 01750_parsing_exception.sh) (in query: SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008e9a727 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e2e9a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:22:25.103559 [ 35674 ] {8f9cf2a4-c129-40c8-9e18-24d57fc08f79} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2021-1-01 00:00:00' as DateTime: syntax error at position 10 (parsed just '2021-1-01 '): In scope SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1')). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008e9a727 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e2e9a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:22:25.319191 [ 35669 ] {fe4da7d0-bb87-499f-8cdf-2f234785b775} BackupsWorker: Failed to restore from backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_2.zip'): Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ZipArchiveReader::showError(String const&) const @ 0x0000000030a5e7c3 4. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x0000000030a6349f 5. ? @ 0x0000000030a652d0 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x0000000030a651d0 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x0000000030a5eb9f 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::BackupImpl::readBackupMetadata() @ 0x00000000318cad8d 9. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000031977e57 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 13. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 14. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 15. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackup() const @ 0x00000000318d3016 16. ./build_docker/./src/Backups/BackupImpl.cpp:763: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x00000000318dfe04 17. ./build_docker/./src/Backups/BackupImpl.cpp:709: DB::BackupImpl::readFile(std::pair> const&) const @ 0x00000000318def3a 18. ./build_docker/./src/Backups/BackupImpl.cpp:704: DB::BackupImpl::readFile(String const&) const @ 0x00000000318deefe 19. ./build_docker/./src/Backups/RestorerFromBackup.cpp:440: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000003187e36e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189b19f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x0000000031899e9a 22. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189a44e 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:22:25.321356 [ 35669 ] {fe4da7d0-bb87-499f-8cdf-2f234785b775} executeQuery: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56742) (comment: 02843_backup_use_same_password_for_base_backup.sh) (in query: RESTORE TABLE data AS data_2 FROM Disk('backups', '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_2.zip') SETTINGS password='password'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ZipArchiveReader::showError(String const&) const @ 0x0000000030a5e7c3 4. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x0000000030a6349f 5. ? @ 0x0000000030a652d0 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x0000000030a651d0 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x0000000030a5eb9f 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::BackupImpl::readBackupMetadata() @ 0x00000000318cad8d 9. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000031977e57 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 13. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 14. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 15. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackup() const @ 0x00000000318d3016 16. ./build_docker/./src/Backups/BackupImpl.cpp:763: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x00000000318dfe04 17. ./build_docker/./src/Backups/BackupImpl.cpp:709: DB::BackupImpl::readFile(std::pair> const&) const @ 0x00000000318def3a 18. ./build_docker/./src/Backups/BackupImpl.cpp:704: DB::BackupImpl::readFile(String const&) const @ 0x00000000318deefe 19. ./build_docker/./src/Backups/RestorerFromBackup.cpp:440: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000003187e36e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189b19f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x0000000031899e9a 22. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189a44e 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:25.327376 [ 35669 ] {fe4da7d0-bb87-499f-8cdf-2f234785b775} TCPHandler: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_u8o9drbc_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ZipArchiveReader::showError(String const&) const @ 0x0000000030a5e7c3 4. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x0000000030a6349f 5. ? @ 0x0000000030a652d0 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:0: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x0000000030a651d0 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x0000000030a5eb9f 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::BackupImpl::readBackupMetadata() @ 0x00000000318cad8d 9. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::open() @ 0x00000000318c3bf5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x00000000318c1c4b 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000031977e57 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000031971b75 13. ./build_docker/./src/Backups/BackupFactory.cpp:25: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000031814f24 14. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x00000000318d1dda 15. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackup() const @ 0x00000000318d3016 16. ./build_docker/./src/Backups/BackupImpl.cpp:763: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x00000000318dfe04 17. ./build_docker/./src/Backups/BackupImpl.cpp:709: DB::BackupImpl::readFile(std::pair> const&) const @ 0x00000000318def3a 18. ./build_docker/./src/Backups/BackupImpl.cpp:704: DB::BackupImpl::readFile(String const&) const @ 0x00000000318deefe 19. ./build_docker/./src/Backups/RestorerFromBackup.cpp:440: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000003187e36e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189b19f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x0000000031899e9a 22. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b45bd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003189a44e 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:25.599584 [ 51843 ] {485b6082-94f4-41e9-8804-d2bcdacac75f} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal32OrZero must be constant: In scope SELECT toDecimal32OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009463c74 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:25.602312 [ 51843 ] {485b6082-94f4-41e9-8804-d2bcdacac75f} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal32OrZero must be constant: In scope SELECT toDecimal32OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009463c74 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:26.410764 [ 51843 ] {95ac0763-44ed-417a-b30e-c0f37756a89e} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal64OrZero must be constant: In scope SELECT toDecimal64OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal64OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009468f94 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:26.413018 [ 51843 ] {95ac0763-44ed-417a-b30e-c0f37756a89e} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal64OrZero must be constant: In scope SELECT toDecimal64OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009468f94 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:27.194738 [ 51843 ] {a7b859fb-f3a6-4493-9051-5045e50c7a61} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal128OrZero must be constant: In scope SELECT toDecimal128OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal128OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000946e314 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:27.197119 [ 51843 ] {a7b859fb-f3a6-4493-9051-5045e50c7a61} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal128OrZero must be constant: In scope SELECT toDecimal128OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000946e314 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:28.100916 [ 51843 ] {6a9db82a-e2f5-48c4-87b9-9259801c329b} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrNull(1.1, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000094f6b56 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:28.103192 [ 51843 ] {6a9db82a-e2f5-48c4-87b9-9259801c329b} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000094f6b56 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:29.486162 [ 51843 ] {7a217647-ed4d-4200-9c51-e17b25f1707d} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal32OrNull must be constant: In scope SELECT toDecimal32OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000094f5769 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:29.488495 [ 51843 ] {7a217647-ed4d-4200-9c51-e17b25f1707d} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal32OrNull must be constant: In scope SELECT toDecimal32OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000094f5769 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:29.600432 [ 51855 ] {85288b66-35d6-4aac-9441-5588b70dd25c} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60836) (comment: 01196_max_parser_depth.sh) (in query: select coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, 1))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000003d04698a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190599 6. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 7. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:29.603856 [ 51855 ] {85288b66-35d6-4aac-9441-5588b70dd25c} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000003d04698a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d190599 6. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d193e50 7. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d194191 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589a612 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:22:30.238848 [ 51843 ] {fbff1046-2b4a-450a-b448-fe518c73a02b} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal64OrNull must be constant: In scope SELECT toDecimal64OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal64OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000094fb7a9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:30.241787 [ 51843 ] {fbff1046-2b4a-450a-b448-fe518c73a02b} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal64OrNull must be constant: In scope SELECT toDecimal64OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000094fb7a9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:30.433355 [ 35674 ] {d51800f6-efdd-4896-9460-9e6259360a78} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: \He\l\l\o, error: invalid escape sequence: \H. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('Hello', '\\He\\l\\l\\o'). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56810) (comment: 01284_escape_sequences_php_mysql_style.sql) (in query: SELECT match('Hello', '\He\l\l\o');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000083b02cd 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000200aa178 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x0000000015fcb2d5 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc2895 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:22:30.435504 [ 35674 ] {d51800f6-efdd-4896-9460-9e6259360a78} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: \He\l\l\o, error: invalid escape sequence: \H. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('Hello', '\\He\\l\\l\\o'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000083b02cd 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000200aa178 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x0000000015fcb2d5 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc2895 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:22:30.461263 [ 35674 ] {2f694147-d480-49e0-af2b-e4adf8d8ac7a} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: \H\l\l\o, error: invalid escape sequence: \H. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('Hello', '\\H\\l\\l\\o'). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56810) (comment: 01284_escape_sequences_php_mysql_style.sql) (in query: SELECT match('Hello', '\H\e\l\l\o');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000083b02cd 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000200aa178 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x0000000015fcb2d5 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc2895 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:22:30.463527 [ 35674 ] {2f694147-d480-49e0-af2b-e4adf8d8ac7a} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: \H\l\l\o, error: invalid escape sequence: \H. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('Hello', '\\H\\l\\l\\o'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000083b02cd 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000200aa178 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x0000000015fcb2d5 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc2895 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:22:30.995227 [ 51843 ] {a4a0e9d4-f23e-43d8-a7d2-839a2ac34136} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal128OrNull must be constant: In scope SELECT toDecimal128OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56706) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal128OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000095017e9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:30.997406 [ 51843 ] {a4a0e9d4-f23e-43d8-a7d2-839a2ac34136} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal128OrNull must be constant: In scope SELECT toDecimal128OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000095017e9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:22:34.192435 [ 35675 ] {d2b84bae-4f2f-42c3-93bd-d34971931432} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe72b10 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:34.195037 [ 35675 ] {d2b84bae-4f2f-42c3-93bd-d34971931432} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe72b10 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:34.810727 [ 35675 ] {23221f3e-b9b2-45ff-a407-b31d5dc4a33d} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:34.813418 [ 35675 ] {23221f3e-b9b2-45ff-a407-b31d5dc4a33d} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:34.843006 [ 35675 ] {8525a3ca-67a6-4cc2-8f2d-636ee8571bd6} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:34.845403 [ 35675 ] {8525a3ca-67a6-4cc2-8f2d-636ee8571bd6} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.192151 [ 36000 ] {fc189e54-fc2f-44a7-a3fa-216cd05a5465} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(Int128) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('{}', 'JSON(a LowCardinality(Int128))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55942) (comment: 03261_json_hints_types_check.sql) (in query: select '{}'::JSON(a LowCardinality(Int128));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:48: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c677 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:35.194356 [ 36000 ] {fc189e54-fc2f-44a7-a3fa-216cd05a5465} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(Int128) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('{}', 'JSON(a LowCardinality(Int128))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:48: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c677 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:35.464945 [ 35675 ] {d0a1dd7a-c402-4044-974b-19acc1cf3877} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.467587 [ 35675 ] {d0a1dd7a-c402-4044-974b-19acc1cf3877} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.494619 [ 35675 ] {a491d008-9306-41b8-b3bb-dd4d0d9bcffd} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.497299 [ 35675 ] {a491d008-9306-41b8-b3bb-dd4d0d9bcffd} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.526043 [ 35675 ] {946c50f4-a342-440c-a834-dbf4d95a5dfa} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1]::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.528646 [ 35675 ] {946c50f4-a342-440c-a834-dbf4d95a5dfa} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.877255 [ 35675 ] {15000df1-1f0d-49b4-8827-2b936e444012} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe72b10 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.880188 [ 35675 ] {15000df1-1f0d-49b4-8827-2b936e444012} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe72b10 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.892366 [ 36000 ] {d4f54ef0-604f-4363-965f-c1ba70ccfb19} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(100000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a FixedString(100000))'). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55942) (comment: 03261_json_hints_types_check.sql) (in query: select '{}'::JSON(a FixedString(100000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000359a066d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c57f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:35.894429 [ 36000 ] {d4f54ef0-604f-4363-965f-c1ba70ccfb19} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(100000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a FixedString(100000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000359a066d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c57f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:35.902939 [ 35675 ] {a49a5924-f2d0-44ba-b8eb-8d2e6917c58d} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.905121 [ 35675 ] {a49a5924-f2d0-44ba-b8eb-8d2e6917c58d} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.928836 [ 35675 ] {e0e6021e-347b-4d22-87ff-46d966fe88e0} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.931095 [ 35675 ] {e0e6021e-347b-4d22-87ff-46d966fe88e0} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.955707 [ 35675 ] {ec0083eb-dddb-4a2b-84b4-7500629fb7ab} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:35.980199 [ 35675 ] {ec0083eb-dddb-4a2b-84b4-7500629fb7ab} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.004572 [ 35675 ] {231fb3dd-7d5e-4319-b98e-dd2ffc43e37a} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.007077 [ 35675 ] {231fb3dd-7d5e-4319-b98e-dd2ffc43e37a} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:0: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe74490 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.031212 [ 35675 ] {250be5dc-08ae-4d87-95bc-c958b6a62caa} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55902) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1]::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.034067 [ 35675 ] {250be5dc-08ae-4d87-95bc-c958b6a62caa} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x00000000083a09aa 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x000000002fe7303a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf0c8 6. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 7. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345096b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.611745 [ 36000 ] {9a6a99e4-ddc3-43f6-b9fd-5d36da6bae9b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Variant(Int32))'). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55942) (comment: 03261_json_hints_types_check.sql) (in query: select '{}'::JSON(a Variant(Int32));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:86: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c345 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:36.613956 [ 36000 ] {9a6a99e4-ddc3-43f6-b9fd-5d36da6bae9b} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Variant(Int32))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:86: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c345 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:36.656752 [ 51918 ] {5e99bd62-df8c-4c20-9e45-9e4862a65e37} executeQuery: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_192572865902391155738371101882021692813): While processing disk(type = cache, max_size = '1Mi', path = '/kek', disk = 'local_disk'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55988) (comment: 02842_filesystem_cache_validate_path.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = cache, max_size = '1Mi', path = '/kek', disk = 'local_disk'), index_granularity = 9824, min_bytes_for_wide_part = 125286452, ratio_of_defaults_for_sparse_serialization = 0.5369667410850525, replace_long_file_name_to_hash = false, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 150166487, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 24313429, merge_max_block_size = 10334, old_parts_lifetime = 460., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6549691297, index_granularity_bytes = 17663998, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 51092, primary_key_compress_block_size = 20416), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ae70d 4. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:0: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x0000000032f4a9c1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032ed48df 6. ./build_docker/./src/Disks/DiskFomAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl, String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000039de2be1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003378ab0d 8. ./build_docker/./src/Disks/DiskFomAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039ddf945 9. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 11. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.661982 [ 51918 ] {5e99bd62-df8c-4c20-9e45-9e4862a65e37} TCPHandler: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_192572865902391155738371101882021692813): While processing disk(type = cache, max_size = '1Mi', path = '/kek', disk = 'local_disk'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ae70d 4. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:0: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x0000000032f4a9c1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032ed48df 6. ./build_docker/./src/Disks/DiskFomAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl, String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000039de2be1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003378ab0d 8. ./build_docker/./src/Disks/DiskFomAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039ddf945 9. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 11. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.719783 [ 51918 ] {d5e69b35-6833-4933-84c3-5d0ba2c2d6b1} executeQuery: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_262870538002818487146265108116777811907): While processing disk(type = cache, max_size = '1Mi', path = '/var/lib/clickhouse/filesystem_caches/../kek', disk = 'local_disk'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55988) (comment: 02842_filesystem_cache_validate_path.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = cache, max_size = '1Mi', path = '/var/lib/clickhouse/filesystem_caches/../kek', disk = 'local_disk'), index_granularity = 9824, min_bytes_for_wide_part = 125286452, ratio_of_defaults_for_sparse_serialization = 0.5369667410850525, replace_long_file_name_to_hash = false, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 150166487, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 24313429, merge_max_block_size = 10334, old_parts_lifetime = 460., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6549691297, index_granularity_bytes = 17663998, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 51092, primary_key_compress_block_size = 20416), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ae70d 4. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:0: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x0000000032f4a9c1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032ed48df 6. ./build_docker/./src/Disks/DiskFomAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl, String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000039de2be1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003378ab0d 8. ./build_docker/./src/Disks/DiskFomAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039ddf945 9. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 11. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.722424 [ 51918 ] {d5e69b35-6833-4933-84c3-5d0ba2c2d6b1} TCPHandler: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_262870538002818487146265108116777811907): While processing disk(type = cache, max_size = '1Mi', path = '/var/lib/clickhouse/filesystem_caches/../kek', disk = 'local_disk'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ae70d 4. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:0: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x0000000032f4a9c1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032ed48df 6. ./build_docker/./src/Disks/DiskFomAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl, String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000039de2be1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003378ab0d 8. ./build_docker/./src/Disks/DiskFomAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039ddf945 9. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 11. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.783802 [ 51918 ] {c1355ac1-ea7f-4ca9-baf4-82c9098ffb81} executeQuery: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_58561455282842823620715320733810034789): While processing disk(type = cache, max_size = '1Mi', path = '../kek', disk = 'local_disk'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55988) (comment: 02842_filesystem_cache_validate_path.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = cache, max_size = '1Mi', path = '../kek', disk = 'local_disk'), index_granularity = 9824, min_bytes_for_wide_part = 125286452, ratio_of_defaults_for_sparse_serialization = 0.5369667410850525, replace_long_file_name_to_hash = false, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 150166487, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 24313429, merge_max_block_size = 10334, old_parts_lifetime = 460., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6549691297, index_granularity_bytes = 17663998, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 51092, primary_key_compress_block_size = 20416), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ae70d 4. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:0: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x0000000032f4a9c1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032ed48df 6. ./build_docker/./src/Disks/DiskFomAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl, String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000039de2be1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003378ab0d 8. ./build_docker/./src/Disks/DiskFomAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039ddf945 9. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 11. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.786457 [ 51918 ] {c1355ac1-ea7f-4ca9-baf4-82c9098ffb81} TCPHandler: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_58561455282842823620715320733810034789): While processing disk(type = cache, max_size = '1Mi', path = '../kek', disk = 'local_disk'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ae70d 4. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:0: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x0000000032f4a9c1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032ed48df 6. ./build_docker/./src/Disks/DiskFomAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl, String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000039de2be1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003378ab0d 8. ./build_docker/./src/Disks/DiskFomAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039ddf945 9. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 11. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 15. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:36.807675 [ 51889 ] {8d4325b7-6811-4fd2-bcbf-f3f6e8742170} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- MIN, MAX AND FAMILY should check for errors in its input SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0df8c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002cebd88f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:36.809863 [ 51889 ] {8d4325b7-6811-4fd2-bcbf-f3f6e8742170} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0df8c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002cebd88f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:36.840418 [ 51889 ] {738e5cf3-43fd-4a2f-8aa8-6703e70a0971} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0df8c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002cebd88f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:36.842657 [ 51889 ] {738e5cf3-43fd-4a2f-8aa8-6703e70a0971} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0df8c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002cebd88f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:37.354586 [ 36000 ] {0d2dcbf7-e98e-4f97-ab96-3410bd58bc0e} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Object(\'json\'))'). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55942) (comment: 03261_json_hints_types_check.sql) (in query: select '{}'::JSON(a Object('json'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:60: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c24e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:37.356807 [ 36000 ] {0d2dcbf7-e98e-4f97-ab96-3410bd58bc0e} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Object(\'json\'))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:60: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003599c24e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000359a04c9 6. ./build_docker/./src/DataTypes/DataTypeObject.cpp:230: DB::DataTypeObject::forEachChild(std::function const&) const @ 0x000000003245a388 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000359995e9 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008390e7d 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:22:37.847446 [ 51889 ] {4a61033b-118a-483d-a4f7-1b168d8e09cb} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- aggThrow should check for errors in its input SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ReadBuffer::throwReadAfterEOF() @ 0x000000000b5f5f0c 5. ./src/IO/BufferBase.h:99: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f602ee1 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:37.850296 [ 51889 ] {4a61033b-118a-483d-a4f7-1b168d8e09cb} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ReadBuffer::throwReadAfterEOF() @ 0x000000000b5f5f0c 5. ./src/IO/BufferBase.h:99: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f602ee1 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:38.718181 [ 51889 ] {48df7186-8d1f-4c7a-87d2-2beb79f832db} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- categoricalInformationValue should check for errors in its input SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f62f5 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:38.720569 [ 51889 ] {48df7186-8d1f-4c7a-87d2-2beb79f832db} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f62f5 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:38.722028 [ 35669 ] {b15b8885-5958-437b-8e40-d3f15c381a37} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56028) (comment: 02915_sleep_large_uint.sql) (in query: SELECT sleep(3.40282e+44);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba2dd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8f34 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:38.725321 [ 35669 ] {b15b8885-5958-437b-8e40-d3f15c381a37} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba2dd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8f34 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:38.783915 [ 35669 ] {247c94ff-08a1-4513-8301-949155ecc2aa} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56028) (comment: 02915_sleep_large_uint.sql) (in query: SELECT sleep((pow(2, 64) / 1000000) - 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba2dd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8f34 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:38.786726 [ 35669 ] {247c94ff-08a1-4513-8301-949155ecc2aa} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba2dd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8f34 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:39.525732 [ 35669 ] {46cbfc9f-4d45-4ad1-8796-0a90945ee74f} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56028) (comment: 02915_sleep_large_uint.sql) (in query: SELECT sleepEachRow(184467440737095516) from numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bd7eb 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc274 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:39.528847 [ 35669 ] {46cbfc9f-4d45-4ad1-8796-0a90945ee74f} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bd7eb 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc274 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033241290 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000003323c3e3 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b800e37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdd4bd5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1781e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0066c 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:39.530317 [ 51889 ] {d99ce6dc-8389-4c6c-b8a4-5954f019aeb4} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f62f5 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:39.532682 [ 51889 ] {d99ce6dc-8389-4c6c-b8a4-5954f019aeb4} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f62f5 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:40.316326 [ 35669 ] {cc0b53c8-54e0-4f31-80a0-5cbb015d35a3} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 4294967295 microseconds. Requested: 2147483648000000 microseconds: while executing 'FUNCTION sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String) :: 1) -> sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String)) UInt8 : 2'. (TOO_SLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56028) (comment: 02915_sleep_large_uint.sql) (in query: SELECT sleepEachRow(pow(2, 31)) from numbers(9007199254740992) settings function_sleep_max_microseconds_per_block = 8589934592000000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000083f3ded 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bd95e 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:40.319437 [ 35669 ] {cc0b53c8-54e0-4f31-80a0-5cbb015d35a3} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 4294967295 microseconds. Requested: 2147483648000000 microseconds: while executing 'FUNCTION sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String) :: 1) -> sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String)) UInt8 : 2'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000083f3ded 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bd95e 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:40.394771 [ 51889 ] {e1e0a28a-8eb6-4a39-8165-84a61deb08c3} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- groupArray should check for errors in its input SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:421: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002b1198e2 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:684: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b19bb17 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:40.397381 [ 51889 ] {e1e0a28a-8eb6-4a39-8165-84a61deb08c3} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:421: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002b1198e2 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:684: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b19bb17 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:40.597109 [ 35659 ] {7652c621-b2d4-42bf-90bd-a6f7b8e56ed4} executeQuery: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT (NULL, NULL, NULL, NULL, NULL, NULL, NULL) FROM numbers(0) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56064) (comment: 02233_with_total_empty_chunk.sql) (in query: SELECT (NULL, NULL, NULL, NULL, NULL, NULL, NULL) FROM numbers(0) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]) -- { serverError ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER }; ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319dd0b7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033583a4a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x0000000033582ddf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e768 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:40.600050 [ 35659 ] {7652c621-b2d4-42bf-90bd-a6f7b8e56ed4} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT (NULL, NULL, NULL, NULL, NULL, NULL, NULL) FROM numbers(0) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319dd0b7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033583a4a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x0000000033582ddf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e768 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:22:41.216872 [ 51889 ] {aebe1a13-6b09-43fe-8665-18d9b107f463} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:351: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b14b366 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:41.219621 [ 51889 ] {aebe1a13-6b09-43fe-8665-18d9b107f463} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:351: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b14b366 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:42.037732 [ 51889 ] {cfd7a716-79d5-4d95-b2d9-10f830694e38} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- Same for groupArrayMovingXXXX SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f39fc5c 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:42.040437 [ 51889 ] {cfd7a716-79d5-4d95-b2d9-10f830694e38} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f39fc5c 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:42.925998 [ 51889 ] {330113f4-be44-4ab6-bc42-ff703fc8845c} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f4ea7ca 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:42.928979 [ 51889 ] {330113f4-be44-4ab6-bc42-ff703fc8845c} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f4ea7ca 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:43.751661 [ 51889 ] {e2cb5ebd-030d-4bea-b069-26e1e1cb3124} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- Histogram SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:310: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x000000002f23ba0e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:370: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f272889 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:43.754442 [ 51889 ] {e2cb5ebd-030d-4bea-b069-26e1e1cb3124} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:310: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x000000002f23ba0e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:370: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f272889 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:44.562392 [ 51889 ] {33ec3a65-c6a3-4ffb-a808-3057c928ef1c} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- StatisticalSample SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:315: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f609a9c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:229: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f615dd2 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:44.565319 [ 51889 ] {33ec3a65-c6a3-4ffb-a808-3057c928ef1c} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:315: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f609a9c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:229: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f615dd2 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:45.360573 [ 51889 ] {cbe24d19-16ad-4390-8c42-58a016dbd55b} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- maxIntersections SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:155: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f19857a 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:45.363631 [ 51889 ] {cbe24d19-16ad-4390-8c42-58a016dbd55b} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:155: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f19857a 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:46.170447 [ 51889 ] {84bc6d85-63cd-412b-8229-9e9b9eedfe3f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- sequenceNextNode (This was fine because it would fail in the next readBinary call, but better to add a test) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(''forward'', ''head''), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63f604 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f64a53a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:22:46.173393 [ 51889 ] {84bc6d85-63cd-412b-8229-9e9b9eedfe3f} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63f604 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f64a53a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:22:46.972679 [ 51889 ] {92e17051-085b-4d83-8e2e-150c68867159} executeQuery: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- Fuzzer (ALL) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:97: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63f86b 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f64a53a 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:46.975095 [ 51889 ] {92e17051-085b-4d83-8e2e-150c68867159} TCPHandler: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:97: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63f86b 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f64a53a 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:47.014978 [ 51889 ] {70e2d119-8c1f-4b33-8227-cb285696f91f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- Fuzzer 2 (UBSAN) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63f604 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f64a53a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:22:47.017395 [ 51889 ] {70e2d119-8c1f-4b33-8227-cb285696f91f} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63f604 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f64a53a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd9be47 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 2025.06.18 11:22:47.869290 [ 51889 ] {cd6647e5-b801-447f-9ac5-d90c3dbd9e8f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- uniqUpTo SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:223: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ed4f027 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:47.871844 [ 51889 ] {cd6647e5-b801-447f-9ac5-d90c3dbd9e8f} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:223: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ed4f027 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 2025.06.18 11:22:48.685109 [ 51889 ] {37fbb8c2-0dc8-49e2-913c-52cea191d7d8} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: -- quantiles SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/AggregateFunctions/QuantileExact.h:65: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x000000002ba6ac0a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ba6542f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:48.687601 [ 51889 ] {37fbb8c2-0dc8-49e2-913c-52cea191d7d8} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/AggregateFunctions/QuantileExact.h:65: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x000000002ba6ac0a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ba6542f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:49.511007 [ 51889 ] {ff7dfdeb-698b-4b5a-b08c-bb02e2a4be3b} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56002) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:315: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x000000002c58ccca 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c5806af 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:22:49.513445 [ 51889 ] {ff7dfdeb-698b-4b5a-b08c-bb02e2a4be3b} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/Common/PODArray.h:315: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x000000002c58ccca 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c5806af 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:23:01.086419 [ 51841 ] {a0178957-fa74-4dcc-8d7a-1e476b28eeb9} executeQuery: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43876) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x01\x00'::AggregateFunction(groupBitmap, UInt32);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:128: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x000000002f17bddf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f088f70 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:23:01.089286 [ 51841 ] {a0178957-fa74-4dcc-8d7a-1e476b28eeb9} TCPHandler: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:128: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x000000002f17bddf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f088f70 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:23:01.173728 [ 35659 ] {d730ee53-23f7-4d94-961b-978f0795475e} executeQuery: Code: 43. DB::Exception: Point's component must not be NaN: In scope SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43850) (comment: 01305_polygons_union.sql) (in query: SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ColumnToPointsConverter>::convert(COW::immutable_ptr) @ 0x000000001a702473 5. DB::ColumnToRingsConverter>::convert(COW::immutable_ptr) @ 0x000000001a706078 6. DB::ColumnToPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000001a7085d9 7. DB::ColumnToMultiPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000001a70b78d 8. void DB::callOnGeometryDataType, auto void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x000000001b625812 9. void DB::callOnGeometryDataType, void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x000000001b5fcef2 10. DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b5fa200 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:23:01.177787 [ 35659 ] {d730ee53-23f7-4d94-961b-978f0795475e} TCPHandler: Code: 43. DB::Exception: Point's component must not be NaN: In scope SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ColumnToPointsConverter>::convert(COW::immutable_ptr) @ 0x000000001a702473 5. DB::ColumnToRingsConverter>::convert(COW::immutable_ptr) @ 0x000000001a706078 6. DB::ColumnToPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000001a7085d9 7. DB::ColumnToMultiPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000001a70b78d 8. void DB::callOnGeometryDataType, auto void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x000000001b625812 9. void DB::callOnGeometryDataType, void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x000000001b5fcef2 10. DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b5fa200 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 2025.06.18 11:23:02.021591 [ 51841 ] {75873cf8-5f8b-480a-8fa2-df50d3a275ac} executeQuery: std::exception. Code: 1001, type: std::runtime_error, e.what() = ran out of bytes (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43876) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x01\x01\x01'::AggregateFunction(groupBitmap, UInt64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(char const*) @ 0x0000000047c5f5a3 1. ./contrib/croaring/cpp/roaring64map.hh:0: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x000000002f17ecdb 2. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:0: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x000000002f17d789 3. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f08dc90 4. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:23:02.024149 [ 51841 ] {75873cf8-5f8b-480a-8fa2-df50d3a275ac} TCPHandler: Code: 1001. DB::Exception: std::runtime_error: ran out of bytes. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(char const*) @ 0x0000000047c5f5a3 1. ./contrib/croaring/cpp/roaring64map.hh:0: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x000000002f17ecdb 2. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:0: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x000000002f17d789 3. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f08dc90 4. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:23:02.866993 [ 51841 ] {49f1d0d7-fa68-4bd6-b4fe-0a21aaaa1b9f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43876) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x02\x00\x0d'::AggregateFunction(topK, UInt256);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/IO/VarInt.h:111: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x000000002eec7373 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:145: DB::(anonymous namespace)::AggregateFunctionTopK, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002edc841a 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:23:02.869444 [ 51841 ] {49f1d0d7-fa68-4bd6-b4fe-0a21aaaa1b9f} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000963122d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000096310a7 5. ./src/IO/VarInt.h:111: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x000000002eec7373 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:145: DB::(anonymous namespace)::AggregateFunctionTopK, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002edc841a 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:23:03.695986 [ 51841 ] {722ee3ef-b38a-4f20-9b2e-9eb5f3162913} executeQuery: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43876) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300')::AggregateFunction(minDistinct, Int8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./src/Common/HashTable/HashTable.h:1334: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x000000002b5807a2 5. ./src/AggregateFunctions/Combinators/AggregateFunctionDistinct.h:198: DB::AggregateFunctionDistinct>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fbcec8f 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:23:03.698532 [ 51841 ] {722ee3ef-b38a-4f20-9b2e-9eb5f3162913} TCPHandler: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./src/Common/HashTable/HashTable.h:1334: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x000000002b5807a2 5. ./src/AggregateFunctions/Combinators/AggregateFunctionDistinct.h:198: DB::AggregateFunctionDistinct>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fbcec8f 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:23:04.457568 [ 51841 ] {84bd2e10-a057-4848-aae9-f3dc0539352c} executeQuery: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43876) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002c39522d 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000002c394a51 5. ./src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000002c3db328 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c3d3e6f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:23:04.460403 [ 51841 ] {84bd2e10-a057-4848-aae9-f3dc0539352c} TCPHandler: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002c39522d 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000002c394a51 5. ./src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000002c3db328 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c3d3e6f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:23:04.461101 [ 35673 ] {139e1abd-aa4b-48ec-bd47-3187fe04f47f} executeQuery: Code: 36. DB::Exception: The fourth argument of function seriesOutliersDetectTukey must be a non-negative number: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3, 5, 6, 4, 5, 12, 45, 12, 3, 3, 4, 5, 6], 0.25, 0.75, -1). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52982) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: -- negative tests SELECT seriesOutliersDetectTukey([-3, 2, 15, 3, 5, 6, 4, 5, 12, 45, 12, 3, 3, 4, 5, 6], .25, .75, -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf23d6e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:04.464039 [ 35673 ] {139e1abd-aa4b-48ec-bd47-3187fe04f47f} TCPHandler: Code: 36. DB::Exception: The fourth argument of function seriesOutliersDetectTukey must be a non-negative number: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3, 5, 6, 4, 5, 12, 45, 12, 3, 3, 4, 5, 6], 0.25, 0.75, -1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf23d6e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:04.487170 [ 51841 ] {06a0b428-8d40-4d67-a954-e8bc96a8fb56} executeQuery: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43876) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('010001')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002c39522d 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000002c394a51 5. ./src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000002c3db328 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c3d3e6f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:23:04.489524 [ 51841 ] {06a0b428-8d40-4d67-a954-e8bc96a8fb56} TCPHandler: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002c39522d 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000002c394a51 5. ./src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000002c3db328 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c3d3e6f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:23:05.220259 [ 35673 ] {9dd91858-1234-4769-b565-85128b105846} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33, 0.53). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52982) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], .33, .53);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf25c60 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:05.224126 [ 35673 ] {9dd91858-1234-4769-b565-85128b105846} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33, 0.53). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf25c60 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:05.234784 [ 51841 ] {6a5daf57-577e-4648-b8e4-4c8c14f90c5d} executeQuery: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43876) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('0a00797979797979797979790a0a6e')::AggregateFunction(minForEach, Ring);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:74: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x000000002fc1be65 5. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:263: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fc18376 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:23:05.237277 [ 51841 ] {6a5daf57-577e-4648-b8e4-4c8c14f90c5d} TCPHandler: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7de54a 4. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:74: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x000000002fc1be65 5. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:263: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fc18376 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x00000000326518e3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000326520fc 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e80f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009007380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:23:05.253315 [ 35673 ] {ea2254b5-e7b9-46cf-b16a-f3b162ee056d} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 2.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52982) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], .33);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf25c60 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:05.255714 [ 35673 ] {ea2254b5-e7b9-46cf-b16a-f3b162ee056d} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 2.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bf25c60 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:06.059772 [ 35673 ] {737b7b1d-3c2b-4e98-86e8-d16edbaccbbf} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nullable(Float64)) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15, NULL]). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52982) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2.4, 15, NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf24ae6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:06.062814 [ 35673 ] {737b7b1d-3c2b-4e98-86e8-d16edbaccbbf} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nullable(Float64)) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15, NULL]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf24ae6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:06.092976 [ 35673 ] {64d2f560-f5ee-4054-9627-9b14c2447c12} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([]). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52982) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf24ae6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:06.095525 [ 35673 ] {64d2f560-f5ee-4054-9627-9b14c2447c12} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf24ae6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:06.911611 [ 35673 ] {6eb9ee7e-72ab-4316-9287-f0ca2111cb37} executeQuery: Code: 36. DB::Exception: At least four data points are needed for function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15]). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52982) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2.4, 15]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesOutliersDetectTukey::executeNumber(DB::IColumn const&, DB::PODArray, 63ul, 64ul> const&, double, double, double, COW::immutable_ptr&) const @ 0x000000001bf33365 5. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf2432c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:23:06.915052 [ 35673 ] {6eb9ee7e-72ab-4316-9287-f0ca2111cb37} TCPHandler: Code: 36. DB::Exception: At least four data points are needed for function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. bool DB::FunctionSeriesOutliersDetectTukey::executeNumber(DB::IColumn const&, DB::PODArray, 63ul, 64ul> const&, double, double, double, COW::immutable_ptr&) const @ 0x000000001bf33365 5. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf2432c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:23:08.443416 [ 35675 ] {f50d0498-4a51-4f5f-9cc8-71b01a411194} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53078) (comment: 01118_is_constant.sql) (in query: select isConstant();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:08.446519 [ 35675 ] {f50d0498-4a51-4f5f-9cc8-71b01a411194} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:08.475492 [ 35675 ] {0fb4b769-aefc-4e99-bd17-5d8fd487ded8} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53078) (comment: 01118_is_constant.sql) (in query: select isConstant(1, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:08.527694 [ 35675 ] {0fb4b769-aefc-4e99-bd17-5d8fd487ded8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b607fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:27.134819 [ 51918 ] {c18ed08e-0b0b-449e-bf17-081e9ffd8837} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54562) (comment: 03131_deprecated_functions.sql) (in query: SELECT number, neighbor(number, 2) FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::(anonymous namespace)::FunctionNeighbor::create(std::shared_ptr) @ 0x0000000018d8aeec 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008383417 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000083bc2da 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x00000000083b9b5e 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x00000000083bbaed 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349a9b7 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:27.138415 [ 51918 ] {c18ed08e-0b0b-449e-bf17-081e9ffd8837} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::(anonymous namespace)::FunctionNeighbor::create(std::shared_ptr) @ 0x0000000018d8aeec 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008383417 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000083bc2da 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x00000000083b9b5e 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x00000000083bbaed 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349a9b7 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:27.924595 [ 51918 ] {938eebf8-3857-4c70-964e-17d86df0a9fb} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54562) (comment: 03131_deprecated_functions.sql) (in query: SELECT runningDifference(number) FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001beb86cc 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008383417 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000083bc2da 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x00000000083b9b5e 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x00000000083bbaed 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349a9b7 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:27.927242 [ 51918 ] {938eebf8-3857-4c70-964e-17d86df0a9fb} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001beb86cc 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008383417 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000083bc2da 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x00000000083b9b5e 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x00000000083bbaed 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349a9b7 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:28.729965 [ 51918 ] {f0c55e55-55c4-4e99-aa11-fe78e41945ea} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54562) (comment: 03131_deprecated_functions.sql) (in query: SELECT k, runningAccumulate(sum_k) AS res FROM (SELECT number as k, sumState(k) AS sum_k FROM numbers(10) GROUP BY k ORDER BY k);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::(anonymous namespace)::FunctionRunningAccumulate::create(std::shared_ptr) @ 0x000000001bea598c 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008383417 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000083bc2da 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x00000000083b9b5e 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x00000000083bbaed 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349a9b7 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:28.733316 [ 51918 ] {f0c55e55-55c4-4e99-aa11-fe78e41945ea} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845cd8a 4. DB::(anonymous namespace)::FunctionRunningAccumulate::create(std::shared_ptr) @ 0x000000001bea598c 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008383417 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000083bc2da 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x00000000083b9b5e 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x00000000083bbaed 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349a9b7 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:29.016274 [ 35659 ] {5c72fa0d-d986-45e2-8ee4-71d80b5c4721} executeQuery: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54612) (comment: 01710_projection_drop_if_exists.sql) (in query: alter table tp drop projection pp;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:408: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000038209f6e 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000380799a6 6. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:29.018959 [ 35659 ] {5c72fa0d-d986-45e2-8ee4-71d80b5c4721} TCPHandler: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:408: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000038209f6e 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000380799a6 6. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:29.411928 [ 35659 ] {413e76a5-3f10-4129-b630-6a8562a2d74f} executeQuery: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54612) (comment: 01710_projection_drop_if_exists.sql) (in query: alter table tp drop projection p;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:408: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000038209f6e 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000380799a6 6. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:29.415351 [ 35659 ] {413e76a5-3f10-4129-b630-6a8562a2d74f} TCPHandler: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:408: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000038209f6e 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000380799a6 6. ./build_docker/./src/Storages/AlterCommands.cpp:1167: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038090e5c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974bfd4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:32.412302 [ 35669 ] {bd55c0aa-9a6d-4949-9a65-311ab0b8a022} executeQuery: Code: 190. DB::Exception: Arrays passed to arrayMap must have equal size. Argument 3 has size 2 which differs with the size of another argument, 3: while executing 'FUNCTION arrayMap(x UInt8, y UInt8 -> plus(x, y) :: 1, _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String) :: 2, _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String) :: 3) -> arrayMap(x UInt8, y UInt8 -> plus(x, y), _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String), _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String)) Array(UInt16) : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57392) (comment: 03001_bad_error_message_higher_order_functions.sh) (in query: SELECT arrayMap((x,y) -> x + y, [1,2,3], [1,2])), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000001cd3c8df 4. DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd4dfac 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:32.417991 [ 35669 ] {bd55c0aa-9a6d-4949-9a65-311ab0b8a022} TCPHandler: Code: 190. DB::Exception: Arrays passed to arrayMap must have equal size. Argument 3 has size 2 which differs with the size of another argument, 3: while executing 'FUNCTION arrayMap(x UInt8, y UInt8 -> plus(x, y) :: 1, _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String) :: 2, _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String) :: 3) -> arrayMap(x UInt8, y UInt8 -> plus(x, y), _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String), _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String)) Array(UInt16) : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000001cd3c8df 4. DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd4dfac 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:37.941250 [ 51918 ] {bec06984-efba-4846-b0fe-714f5396a0ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57416) (comment: 00972_geohashesInBox.sql) (in query: SELECT geohashesInBox();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:37.943378 [ 51918 ] {bec06984-efba-4846-b0fe-714f5396a0ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60b797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b607685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60880b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:38.561819 [ 35673 ] {c997d757-7b5f-48f5-b605-e49e3e056c58} executeQuery: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57502) (comment: 01045_array_zip.sql) (in query: SELECT arrayZip();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f1572cc 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:38.564753 [ 35673 ] {c997d757-7b5f-48f5-b605-e49e3e056c58} TCPHandler: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f1572cc 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:38.728801 [ 51918 ] {0a988449-32c9-4af1-a838-ef6a7dbd98ca} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitute_min' to function 'geohashesInBox'. Expected: Float*, got: UInt8: In scope SELECT geohashesInBox(1, 2, 3, 4, 5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57416) (comment: 00972_geohashesInBox.sql) (in query: SELECT geohashesInBox(1, 2, 3, 4, 5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionGeohashesInBox::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe871f8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:23:38.731221 [ 51918 ] {0a988449-32c9-4af1-a838-ef6a7dbd98ca} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitute_min' to function 'geohashesInBox'. Expected: Float*, got: UInt8: In scope SELECT geohashesInBox(1, 2, 3, 4, 5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::(anonymous namespace)::FunctionGeohashesInBox::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe871f8 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:23:39.334701 [ 35673 ] {d02a91d6-b9f4-4d51-9e91-a02f05883dac} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayZip must be array. Found String instead.: In scope SELECT arrayZip('a', 'b', 'c'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57502) (comment: 01045_array_zip.sql) (in query: SELECT arrayZip('a', 'b', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f157048 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:39.337205 [ 35673 ] {d02a91d6-b9f4-4d51-9e91-a02f05883dac} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayZip must be array. Found String instead.: In scope SELECT arrayZip('a', 'b', 'c'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f157048 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:39.513230 [ 51918 ] {77b60368-1bb7-43e0-8c60-3e28cb222cc3} executeQuery: Code: 43. DB::Exception: Illegal type of argument of geohashesInBox all coordinate arguments must have the same type, instead they are:Float32, Float64, Float64, Float64.: In scope SELECT geohashesInBox(toFloat32(1.), 2., 3., 4., 5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57416) (comment: 00972_geohashesInBox.sql) (in query: SELECT geohashesInBox(toFloat32(1.0), 2.0, 3.0, 4.0, 5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&) @ 0x000000000fe882c7 4. DB::(anonymous namespace)::FunctionGeohashesInBox::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe87d72 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:39.515702 [ 51918 ] {77b60368-1bb7-43e0-8c60-3e28cb222cc3} TCPHandler: Code: 43. DB::Exception: Illegal type of argument of geohashesInBox all coordinate arguments must have the same type, instead they are:Float32, Float64, Float64, Float64.: In scope SELECT geohashesInBox(toFloat32(1.), 2., 3., 4., 5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&) @ 0x000000000fe882c7 4. DB::(anonymous namespace)::FunctionGeohashesInBox::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe87d72 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:23:40.154625 [ 35673 ] {4e329c2f-159b-4518-b7b0-c76b81f5c794} executeQuery: Code: 190. DB::Exception: The argument 1 and argument 2 of function arrayZip have different array sizes: In scope SELECT arrayZip(['a', 'b', 'c'], ['d', 'e', 'f', 'd']). (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57502) (comment: 01045_array_zip.sql) (in query: SELECT arrayZip(['a', 'b', 'c'], ['d', 'e', 'f', 'd']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x0000000018d95f2d 4. DB::FunctionArrayZip::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f155ab3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:40.157070 [ 35673 ] {4e329c2f-159b-4518-b7b0-c76b81f5c794} TCPHandler: Code: 190. DB::Exception: The argument 1 and argument 2 of function arrayZip have different array sizes: In scope SELECT arrayZip(['a', 'b', 'c'], ['d', 'e', 'f', 'd']). (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x0000000018d95f2d 4. DB::FunctionArrayZip::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f155ab3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:40.323110 [ 51918 ] {d6972255-9550-4193-8b6a-663c64b6f819} executeQuery: Code: 128. DB::Exception: geohashesInBox would produce 1356640814682 array elements, which is bigger than the allowed maximum of 10000000: In scope SELECT geohashesInBox(24.48, 40.56, 24.785, 40.81, 12). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57416) (comment: 00972_geohashesInBox.sql) (in query: SELECT geohashesInBox(24.48, 40.56, 24.785, 40.81, 12);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, unsigned long const&) @ 0x000000000fe883d7 4. DB::(anonymous namespace)::FunctionGeohashesInBox::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe84a30 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:40.325708 [ 51918 ] {d6972255-9550-4193-8b6a-663c64b6f819} TCPHandler: Code: 128. DB::Exception: geohashesInBox would produce 1356640814682 array elements, which is bigger than the allowed maximum of 10000000: In scope SELECT geohashesInBox(24.48, 40.56, 24.785, 40.81, 12). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, unsigned long const&) @ 0x000000000fe883d7 4. DB::(anonymous namespace)::FunctionGeohashesInBox::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe84a30 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:44.650512 [ 51843 ] {75938fae-8094-4064-b9ba-069f14f47835} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49148) (comment: 02815_range_dict_no_direct_join.sql) (in query: SELECT id, amount FROM ids INNER JOIN discounts_dict ON id = advertiser_id ORDER BY id, amount SETTINGS join_algorithm = 'direct';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:44.653404 [ 51843 ] {75938fae-8094-4064-b9ba-069f14f47835} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddb257 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d84785 6. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:45.026942 [ 51854 ] {7b128d5d-073b-405c-8f19-f08794fd4456} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3NumHexagons is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3NumHexagons(16). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49110) (comment: 02165_h3_num_hexagons.sql) (in query: SELECT h3NumHexagons(16);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3NumHexagons::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012381bbe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:45.029522 [ 51854 ] {7b128d5d-073b-405c-8f19-f08794fd4456} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3NumHexagons is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3NumHexagons(16). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fe6edf7 4. DB::(anonymous namespace)::FunctionH3NumHexagons::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012381bbe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:23:46.700236 [ 51843 ] {f7be3248-e5c1-4380-9833-a3c5547a2374} ~StorageFileSource: Failed to rename file /var/lib/clickhouse/user_files/02732_rename_after_processing_test_lu9q1uy9/tmp5.csv: File /var/lib/clickhouse/user_files/02732_rename_after_processing_test_lu9q1uy9/tmp.csv already exists 2025.06.18 11:23:46.924218 [ 35671 ] {26a27698-092b-4f53-8717-389cd6a90797} executeQuery: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49206) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: CREATE TABLE t_row_exists (`a` int, `_row_exists` int) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 50694, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.33272406458854675, replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 507133681, compact_parts_max_bytes_to_buffer = 371326225, compact_parts_max_granules_to_buffer = 140, compact_parts_merge_max_bytes_to_prefetch_part = 27776867, merge_max_block_size = 16691, old_parts_lifetime = 96., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1917474354, index_granularity_bytes = 30494570, concurrent_part_removal_threshold = 33, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 71621, primary_key_compress_block_size = 20831), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:932: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000348b09ba 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1677: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d3109 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:46.930550 [ 35671 ] {26a27698-092b-4f53-8717-389cd6a90797} TCPHandler: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:932: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000348b09ba 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1677: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d3109 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:47.409769 [ 35671 ] {1fc4e1f7-9d5a-4f2e-9564-f5efb0260c52} executeQuery: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49206) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists add column _row_exists int;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1343: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3267 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:47.412357 [ 35671 ] {1fc4e1f7-9d5a-4f2e-9564-f5efb0260c52} TCPHandler: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1343: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3267 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:47.488302 [ 35664 ] {d27095b5-c80c-4758-b9d0-8e0ea8c90053} ~StorageFileSource: Failed to rename file /var/lib/clickhouse/user_files/02732_rename_after_processing_test_lu9q1uy9/tmp5.csv: File `/var/lib/clickhouse/tmp5.csv` is not inside `/var/lib/clickhouse/user_files/` 2025.06.18 11:23:47.796925 [ 35671 ] {10d147f3-4f5b-4bd4-8f4f-9133d2df66df} executeQuery: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49206) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists rename column b to _row_exists;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1568: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a147a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:47.799433 [ 35671 ] {10d147f3-4f5b-4bd4-8f4f-9133d2df66df} TCPHandler: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1568: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a147a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:48.155082 [ 35671 ] {d0c4812f-cf62-4d1b-a86d-b729dec6aa18} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49206) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists rename column _row_exists to c;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a19ea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:48.157685 [ 35671 ] {d0c4812f-cf62-4d1b-a86d-b729dec6aa18} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a19ea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:48.185427 [ 35671 ] {1edb87c2-d1a8-4fab-b66a-0fed6761ffaa} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49206) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists drop column _row_exists;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3950 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:48.188161 [ 35671 ] {1edb87c2-d1a8-4fab-b66a-0fed6761ffaa} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3950 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:48.217529 [ 35671 ] {c4f0a61c-25c0-4eed-8b8c-93f72778cb5c} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49206) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists drop column unknown_column;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3950 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:48.220384 [ 35671 ] {c4f0a61c-25c0-4eed-8b8c-93f72778cb5c} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a3950 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857511 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:23:48.864708 [ 35664 ] {9cd791ff-6efe-42d5-a85a-26e47d5b8731} executeQuery: Code: 36. DB::Exception: Invalid renaming rule: Allowed placeholders only %a, %f, %e, %t, and %%. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49250) (comment: 02732_rename_after_processing.sh) (in query: SELECT COUNT(*) FROM file('02732_rename_after_processing_test_lu9q1uy9/tmp5.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/FileRenamer.cpp:77: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x000000003836bc3d 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x0000000038369ee4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310780 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:23:48.869418 [ 35664 ] {9cd791ff-6efe-42d5-a85a-26e47d5b8731} TCPHandler: Code: 36. DB::Exception: Invalid renaming rule: Allowed placeholders only %a, %f, %e, %t, and %%. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/FileRenamer.cpp:77: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x000000003836bc3d 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x0000000038369ee4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310780 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:23:50.351398 [ 1585 ] {c7a09982-bd70-4875-bb0e-e8d923de5e88} executeQuery: Code: 36. DB::Exception: Invalid renaming rule: Odd number of consecutive percentage signs. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49272) (comment: 02732_rename_after_processing.sh) (in query: SELECT COUNT(*) FROM file('02732_rename_after_processing_test_lu9q1uy9/tmp5.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/FileRenamer.cpp:90: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x000000003836bdba 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x0000000038369ee4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310780 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:23:50.363766 [ 1585 ] {c7a09982-bd70-4875-bb0e-e8d923de5e88} TCPHandler: Code: 36. DB::Exception: Invalid renaming rule: Odd number of consecutive percentage signs. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Common/FileRenamer.cpp:90: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x000000003836bdba 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x0000000038369ee4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310780 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:23:58.124238 [ 24835 ] {86bbce69-ac1a-444c-a63c-062ec8cc96ec} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (9000) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 0).). 2025.06.18 11:24:06.419403 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 0).). 2025.06.18 11:24:06.477072 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9000).). 2025.06.18 11:24:06.477220 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9001).). 2025.06.18 11:24:06.477299 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9002).). 2025.06.18 11:24:06.477702 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9003).). 2025.06.18 11:24:06.477809 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9004).). 2025.06.18 11:24:06.477891 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9005).). 2025.06.18 11:24:06.477959 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9006).). 2025.06.18 11:24:06.478051 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9007).). 2025.06.18 11:24:06.478145 [ 35047 ] {594ddd15-7230-44f2-97aa-f4f94b72dadc::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9008).). 2025.06.18 11:24:07.708381 [ 35671 ] {8e6be31b-5767-4571-8c68-8b6f0488aa21} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50844) (comment: 00732_quorum_insert_lost_part_zookeeper_long.sql) (in query: INSERT INTO quorum2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1229: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003a1f0731 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1166: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003a233112 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a232aff 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a1e9ebb 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1bbe74 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a1e6838 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:07.732698 [ 35671 ] {8e6be31b-5767-4571-8c68-8b6f0488aa21} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1229: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003a1f0731 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1166: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003a233112 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a232aff 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a1e9ebb 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1bbe74 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a1e6838 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:10.362845 [ 35636 ] {6d78aa31-b014-4267-97d0-b0d175dd07c2} executeQuery: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). (CYCLIC_ALIASES) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50918) (comment: 00818_alias_bug_4110.sql) (in query: select a + 1 as b, b + 1 as a from (select 10 as a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1114: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347463e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347312e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 12. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:24:10.366062 [ 35636 ] {6d78aa31-b014-4267-97d0-b0d175dd07c2} TCPHandler: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1114: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347463e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347312e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334765c9 12. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033443bd3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:24:11.079355 [ 35636 ] {33c4ee18-301b-4bb4-aef5-acaec95ce743} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50918) (comment: 00818_alias_bug_4110.sql) (in query: select 10 as a, a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:11.082937 [ 35636 ] {33c4ee18-301b-4bb4-aef5-acaec95ce743} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:11.117228 [ 35636 ] {682df028-7e94-4f62-ba0b-35e70485020d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'a' in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50918) (comment: 00818_alias_bug_4110.sql) (in query: with 10 as a select a as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:11.119870 [ 35636 ] {682df028-7e94-4f62-ba0b-35e70485020d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'a' in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:11.153588 [ 35636 ] {8bdd0237-86c0-47ae-8be7-2c8348607495} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50918) (comment: 00818_alias_bug_4110.sql) (in query: with 10 as a select a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:11.156381 [ 35636 ] {8bdd0237-86c0-47ae-8be7-2c8348607495} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:11.596101 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.607542 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.615728 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.624217 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.634918 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.643867 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.651890 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.658963 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.665713 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:11.673429 [ 35674 ] {589dbfa4-beee-4f28-95cb-09c9cee8128f} test_k7y330bd.rmt (ReplicatedMergeTreeQueue): Partition id '123' was provided as a hint, but there's not such partition in ZooKeeper 2025.06.18 11:24:12.302814 [ 35674 ] {72330c0b-ca28-4712-8d81-8887e2e67a2c} executeQuery: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50878) (comment: 02439_merge_selecting_partitions.sql) (in query: optimize table rmt partition tuple(123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5823: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389067e7 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000388fde79 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:12.370562 [ 35674 ] {72330c0b-ca28-4712-8d81-8887e2e67a2c} TCPHandler: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5823: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389067e7 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000388fde79 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:14.275576 [ 51843 ] {9a3a75fb-f36c-43d9-a540-82911539dbce} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 5 and 1. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:129: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x00000000321ed27e 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x00000000322144ca 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:318: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x00000000320dd46f 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x00000000320d8166 7. DB::ReadBuffer::next() @ 0x00000000095b2aaf 8. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000030f3e586 9. DB::ReadBuffer::next() @ 0x00000000095b2aaf 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:88: DB::ConcatReadBuffer::nextImpl() @ 0x0000000033673117 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b21c2 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:24:14.532526 [ 51843 ] {0d2e19d1-bec3-41e4-810a-e497b31b0840} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 1 and 6. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:129: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x00000000321ed27e 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x00000000322144ca 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:318: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x00000000320dd46f 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x00000000320d8166 7. DB::ReadBuffer::next() @ 0x00000000095b2aaf 8. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000030f3e586 9. DB::ReadBuffer::next() @ 0x00000000095b2aaf 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:88: DB::ConcatReadBuffer::nextImpl() @ 0x0000000033673117 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b21c2 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:24:19.547541 [ 35005 ] {9f221a09-8e73-4bb6-9dde-287ca980c623} executeQuery: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt16) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 21701, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 417403524, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 23760074, merge_max_block_size = 30, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2711623950, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1820191, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67224, primary_key_compress_block_size = 39590), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1031: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396aa093 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:19.551171 [ 35005 ] {9f221a09-8e73-4bb6-9dde-287ca980c623} TCPHandler: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1031: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396aa093 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:20.259265 [ 35005 ] {8e6072c3-9393-4412-80b4-39a14844ce06} executeQuery: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` String, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 21701, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 417403524, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 23760074, merge_max_block_size = 30, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2711623950, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1820191, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67224, primary_key_compress_block_size = 39590), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:997: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x00000000396c6e2e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a8998 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:20.262102 [ 35005 ] {8e6072c3-9393-4412-80b4-39a14844ce06} TCPHandler: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:997: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x00000000396c6e2e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a8998 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:20.957414 [ 35005 ] {3eabf339-b3b0-40d3-ae62-6e9ccd1a6f32} executeQuery: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(is_deleted, is_deleted) ORDER BY key SETTINGS index_granularity = 21701, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 417403524, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 23760074, merge_max_block_size = 30, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2711623950, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1820191, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67224, primary_key_compress_block_size = 39590), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a9615 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:20.960033 [ 35005 ] {3eabf339-b3b0-40d3-ae62-6e9ccd1a6f32} TCPHandler: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a9615 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:21.564074 [ 35005 ] {f89b9120-71d0-477a-86fd-aa4dab5f6499} executeQuery: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN ver String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3170: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759bd8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:21.566491 [ 35005 ] {f89b9120-71d0-477a-86fd-aa4dab5f6499} TCPHandler: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3170: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759bd8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.711623 [ 35005 ] {e7185f42-8eb8-4e17-8403-54ebe7401fb3} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.715009 [ 35005 ] {e7185f42-8eb8-4e17-8403-54ebe7401fb3} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.773974 [ 35005 ] {5b4b47a1-db57-483e-9d2d-872cde5d9379} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted UInt16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.776526 [ 35005 ] {5b4b47a1-db57-483e-9d2d-872cde5d9379} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.828600 [ 35005 ] {bcec3f3c-b438-4047-b6fd-be3626c51e9a} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted Int8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.830914 [ 35005 ] {bcec3f3c-b438-4047-b6fd-be3626c51e9a} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.881289 [ 35005 ] {6fa2f852-bb3f-40ce-930c-bd01eed3222b} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing DROP COLUMN ver;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3349: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000397579b0 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:22.885056 [ 35005 ] {6fa2f852-bb3f-40ce-930c-bd01eed3222b} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3349: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000397579b0 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:23.061899 [ 35659 ] {596d2040-e0ea-4bde-a00d-0bbf407c38b6} executeQuery: Code: 128. DB::Exception: Array size -231 cannot be negative: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(-231.37104, -138). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59144) (comment: 00842_array_with_constant_overflow.sql) (in query: SELECT arrayWithConstant(-231.37104, -138);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x0000000018d8f7ad 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f150f84 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:24:23.064154 [ 35659 ] {596d2040-e0ea-4bde-a00d-0bbf407c38b6} TCPHandler: Code: 128. DB::Exception: Array size -231 cannot be negative: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(-231.37104, -138). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x0000000018d8f7ad 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f150f84 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:24:23.590715 [ 35005 ] {1e347f23-a82b-41e8-b05b-24047d9ee737} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing DROP COLUMN is_deleted;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:908: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a206 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:23.593001 [ 35005 ] {1e347f23-a82b-41e8-b05b-24047d9ee737} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:908: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a206 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:23.661402 [ 35005 ] {9cd664bc-cdfc-4af4-9b68-d42ffa8935e7} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing RENAME COLUMN ver TO ver2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3354: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039757c5a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:23.663853 [ 35005 ] {9cd664bc-cdfc-4af4-9b68-d42ffa8935e7} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3354: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039757c5a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:24.373293 [ 35005 ] {255caaaa-cfcc-41a7-b69f-8996c369fe8c} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing RENAME COLUMN is_deleted TO is_deleted2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:916: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a328 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:24.376771 [ 35005 ] {255caaaa-cfcc-41a7-b69f-8996c369fe8c} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:916: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a328 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.100035 [ 35005 ] {bc1b2606-e932-48fc-8b3a-a4ab78e87ce9} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` Int16) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 21701, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 417403524, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 23760074, merge_max_block_size = 30, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2711623950, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1820191, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67224, primary_key_compress_block_size = 39590), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:970: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x00000000396c5f4e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a6a62 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.102985 [ 35005 ] {bc1b2606-e932-48fc-8b3a-a4ab78e87ce9} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:970: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x00000000396c5f4e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a6a62 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.186333 [ 35005 ] {0b26f142-d744-4be6-8221-160d78881714} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 21701, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 417403524, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 23760074, merge_max_block_size = 30, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2711623950, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1820191, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67224, primary_key_compress_block_size = 39590), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:970: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x00000000396c5f4e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a6a62 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.189499 [ 35005 ] {0b26f142-d744-4be6-8221-160d78881714} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x0000000032b510f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:970: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x00000000396c5f4e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a6a62 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.311588 [ 35675 ] {43d34062-a752-4ab0-9474-45a3f2d5f340} executeQuery: Code: 127. DB::Exception: Duplicated index name idx_a is not allowed. Please use different index names. (ILLEGAL_INDEX) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59196) (comment: 02884_duplicate_index_name.sql) (in query: CREATE TABLE test_dup_index (`a` Int64, `b` Int64, INDEX idx_a a TYPE minmax GRANULARITY 1, INDEX idx_a b TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 26063, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.36689627170562744, replace_long_file_name_to_hash = false, max_file_name_length = 96, min_bytes_for_full_part_storage = 184491240, compact_parts_max_bytes_to_buffer = 101270120, compact_parts_max_granules_to_buffer = 52, compact_parts_merge_max_bytes_to_prefetch_part = 3454477, merge_max_block_size = 3167, old_parts_lifetime = 181., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 54, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 24071647, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 76863, primary_key_compress_block_size = 53136), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:780: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a8fcb 5. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.314431 [ 35675 ] {43d34062-a752-4ab0-9474-45a3f2d5f340} TCPHandler: Code: 127. DB::Exception: Duplicated index name idx_a is not allowed. Please use different index names. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:780: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a8fcb 5. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.893219 [ 35005 ] {8079001f-3bd1-4733-ba6a-05dcf570d5a1} executeQuery: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(not_existing) ORDER BY key SETTINGS index_granularity = 21701, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 417403524, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 23760074, merge_max_block_size = 30, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2711623950, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1820191, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67224, primary_key_compress_block_size = 39590), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:977: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x00000000396c5cf9 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a6a62 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:25.896252 [ 35005 ] {8079001f-3bd1-4733-ba6a-05dcf570d5a1} TCPHandler: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:977: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x00000000396c5cf9 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a6a62 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.160803 [ 35005 ] {468d665e-3516-4c2d-8ab2-f0605c909950} executeQuery: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing MODIFY COLUMN sign String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.163174 [ 35005 ] {468d665e-3516-4c2d-8ab2-f0605c909950} TCPHandler: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000398fb9ff 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:897: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a439 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.207527 [ 35005 ] {ca1a199d-d2e5-451f-9e5c-2e65889fd679} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing DROP COLUMN sign;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:908: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a206 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.211411 [ 35005 ] {ca1a199d-d2e5-451f-9e5c-2e65889fd679} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:908: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a206 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.262317 [ 35005 ] {f2b103ad-794b-4d68-b7ff-bcfeef9b51af} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing RENAME COLUMN sign TO sign2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:916: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a328 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.264775 [ 35005 ] {f2b103ad-794b-4d68-b7ff-bcfeef9b51af} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000398fbb0d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:916: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x000000003976a328 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.972830 [ 35005 ] {a3f21460-4b2f-4ad8-9b1a-d015c92be6bc} executeQuery: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing MODIFY COLUMN sign MODIFY SETTING max_compress_block_size = 123456;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x00000000398fb8ed 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:889: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000039769f70 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:26.975910 [ 35005 ] {a3f21460-4b2f-4ad8-9b1a-d015c92be6bc} TCPHandler: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x00000000398fb8ed 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:889: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000039769f70 5. ./contrib/llvm-project/libcxx/include/string:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974f8e5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:27.303522 [ 35669 ] {77207417-6ad3-4170-986a-b12b9cebd83c} executeQuery: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59230) (comment: 02874_analysis_of_variance_overflow.sql) (in query: SELECT analysisOfVariance(1, 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000083f3ded 4. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x000000002fb58cd4 5. ./src/AggregateFunctions/IAggregateFunction.h:530: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002fb558ea 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000033b55d59 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1463: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d73f 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 9. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:27.310670 [ 35669 ] {77207417-6ad3-4170-986a-b12b9cebd83c} TCPHandler: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000083f3ded 4. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x000000002fb58cd4 5. ./src/AggregateFunctions/IAggregateFunction.h:530: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002fb558ea 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000033b55d59 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1463: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d73f 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 9. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:27.676650 [ 35005 ] {74115976-46da-42ba-9dbc-e8479208c1d2} executeQuery: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41136) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE versioned_collapsing_wrong (`key` Int64, `version` UInt8, `sign` Int8) ENGINE = VersionedCollapsingMergeTree(sign, sign) ORDER BY key SETTINGS index_granularity = 21701, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 417403524, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 23760074, merge_max_block_size = 30, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2711623950, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1820191, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67224, primary_key_compress_block_size = 39590), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a9755 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:27.679927 [ 35005 ] {74115976-46da-42ba-9dbc-e8479208c1d2} TCPHandler: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396a9755 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396a2b54 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2c4cd0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2c310f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2123 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:27.846915 [ 35659 ] {9366134f-8c01-4d6d-9676-2dc484f39e81} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_j3nwea9r.a INNER JOIN (SELECT b AS j, b AS bb FROM test_j3nwea9r.b) USING (j). (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59216) (comment: 03107_ill_formed_select_in_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW view_4 ( bb UInt64, cnt UInt64) Engine=MergeTree ORDER BY bb POPULATE AS SELECT bb, count() AS cnt FROM (SELECT a, b AS j, b AS bb FROM a INNER JOIN (SELECT b AS j, b AS bb FROM b ) USING (j)) GROUP BY bb;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e11c0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9bd23 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x00000000348df203 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1488: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348beaec 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:27.851136 [ 35659 ] {9366134f-8c01-4d6d-9676-2dc484f39e81} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_j3nwea9r.a INNER JOIN (SELECT b AS j, b AS bb FROM test_j3nwea9r.b) USING (j). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f5f7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ecec0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1393 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e11c0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9bd23 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x00000000348df203 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1488: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348beaec 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:29.647518 [ 1585 ] {a1a8eded-a575-4c3d-b0e0-08391203b886} executeQuery: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.capnp. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59278) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_6xwytcp3-data', CapnProto) select * from numbers(10) settings output_format_schema='/tmp/schema.capnp'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:130: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1ef05a 5. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowOutputFormat.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b1f6fab 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:29.655538 [ 1585 ] {a1a8eded-a575-4c3d-b0e0-08391203b886} TCPHandler: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.capnp. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:130: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1ef05a 5. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowOutputFormat.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b1f6fab 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:31.240479 [ 1585 ] {974b0603-75c1-4151-8975-81ae0fa7314a} executeQuery: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.capnp not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59318) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_6xwytcp3-data', CapnProto) select * from numbers(10) settings output_format_schema='../../schema.capnp'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:135: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1ef31c 5. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowOutputFormat.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b1f6fab 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:31.247295 [ 1585 ] {974b0603-75c1-4151-8975-81ae0fa7314a} TCPHandler: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.capnp not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:135: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1ef31c 5. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowOutputFormat.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b1f6fab 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:34.813159 [ 35005 ] {18359742-abb5-45d0-afcb-4291c6bc37aa} executeQuery: Code: 36. DB::Exception: Engine Distributed doesn't support skipping indices. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58384) (comment: 01011_test_create_as_skip_indices.sql) (in query: CREATE TABLE dist (key int, INDEX i1 key TYPE minmax GRANULARITY 1) Engine=Distributed(test_shard_localhost, currentDatabase(), 'foo');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x0000000020656f97 4. ./build_docker/./src/Storages/StorageFactory.cpp:172: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000382f63e0 5. ./build_docker/./src/Storages/StorageFactory.cpp:0: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f40fb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:34.816959 [ 35005 ] {18359742-abb5-45d0-afcb-4291c6bc37aa} TCPHandler: Code: 36. DB::Exception: Engine Distributed doesn't support skipping indices. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x0000000020656f97 4. ./build_docker/./src/Storages/StorageFactory.cpp:172: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000382f63e0 5. ./build_docker/./src/Storages/StorageFactory.cpp:0: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f40fb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:45.823024 [ 51918 ] {0f9b22c0-eee3-4e41-97ba-02387c7991f7} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33490) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv', 'CSV', 'a String, b String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:45.881879 [ 51918 ] {0f9b22c0-eee3-4e41-97ba-02387c7991f7} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:47.318158 [ 51889 ] {43723934-9014-4729-9539-847f103d27aa} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33502) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv', 'CSV', 'a String, b String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:47.328522 [ 51889 ] {43723934-9014-4729-9539-847f103d27aa} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:50.498891 [ 35675 ] {c825ed41-7dae-41e1-8d5a-d00443a6d5c2} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33626) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv.gz', 'CSV', 'a String, b String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:50.507803 [ 35675 ] {c825ed41-7dae-41e1-8d5a-d00443a6d5c2} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:51.432943 [ 35664 ] {cd82fc25-b7e5-4875-83b8-9af2b1cfbbcd} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33664) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv.gz', 'CSV', 'a String, b String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:51.440746 [ 35664 ] {cd82fc25-b7e5-4875-83b8-9af2b1cfbbcd} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x00000000201904d5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b14f88e 5. ./contrib/llvm-project/libcxx/include/vector:1491: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b0a80e6 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:52.557696 [ 51889 ] {c216429a-cafa-4fe1-8fcd-6c6c2c94fdd5} DiskLocal: Cannot create the root directory of disk __tmp_internal_96338278750696980453966033776619367191 (/local/). 2025.06.18 11:24:52.558733 [ 51889 ] {c216429a-cafa-4fe1-8fcd-6c6c2c94fdd5} DiskLocal: Cannot gain read access of the disk directory: /local/ 2025.06.18 11:24:53.259739 [ 51889 ] {c216429a-cafa-4fe1-8fcd-6c6c2c94fdd5} DiskLocal: Disk __tmp_internal_96338278750696980453966033776619367191 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: /local/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x00000000201471ef 4. ./contrib/llvm-project/libcxx/include/optional:344: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000020146945 5. ./contrib/llvm-project/libcxx/include/string:1499: FS::canRead(String const&) @ 0x000000002015e497 6. ./build_docker/./src/Disks/DiskLocal.cpp:621: DB::DiskLocal::setup() @ 0x0000000032ebe816 7. ./build_docker/./src/Disks/DiskLocal.cpp:701: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000032ec0df7 8. ./build_docker/./src/Disks/IDisk.cpp:0: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000032ef8e44 9. ./build_docker/./src/Disks/DiskLocal.cpp:0: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x0000000032ec3823 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032ed48df 11. ./build_docker/./src/Disks/DiskFomAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl, String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000039de2be1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003378ab0d 13. ./build_docker/./src/Disks/DiskFomAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039ddf945 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 15. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 16. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 18. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 20. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:24:53.853826 [ 51889 ] {c216429a-cafa-4fe1-8fcd-6c6c2c94fdd5} executeQuery: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56934) (comment: 02454_create_table_with_custom_disk.sql) (in query: CREATE TABLE test (a Int32) ENGINE = MergeTree() order by tuple() SETTINGS disk = disk(type=local, path='/local/');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039de0e9d 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 7. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:53.856734 [ 51889 ] {c216429a-cafa-4fe1-8fcd-6c6c2c94fdd5} TCPHandler: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039de0e9d 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039de4261 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039de3c55 7. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039de19c8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d7bb8f 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2af27f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:55.172859 [ 59098 ] {0e6ebf5d-58b2-4e49-bfb1-123eb864c156} executeQuery: Code: 442. DB::Exception: Temporary tables cannot be inside a database. You should not specify a database for a temporary table. (BAD_DATABASE_FOR_TEMPORARY_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57008) (comment: 00841_temporary_table_database.sql) (in query: CREATE TEMPORARY TABLE test.t2_00841 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1232: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c04d7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:55.175594 [ 59098 ] {0e6ebf5d-58b2-4e49-bfb1-123eb864c156} TCPHandler: Code: 442. DB::Exception: Temporary tables cannot be inside a database. You should not specify a database for a temporary table. (BAD_DATABASE_FOR_TEMPORARY_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1232: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c04d7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:57.556548 [ 51854 ] {c6c5d3d2-dd52-460f-a551-f2b529fd92ad} executeQuery: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.proto. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57104) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_6xwytcp3-data', Protobuf) select * from numbers(10) settings output_format_schema='/tmp/schema.proto'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:130: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1f44da 5. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowOutputFormat.cpp:64: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b680fe7 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:57.562032 [ 51854 ] {c6c5d3d2-dd52-460f-a551-f2b529fd92ad} TCPHandler: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.proto. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:130: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1f44da 5. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowOutputFormat.cpp:64: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b680fe7 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:57.671598 [ 35669 ] {2997defe-f275-49ff-970b-f8daa54f98bc} executeQuery: Code: 59. DB::Exception: Illegal type Float64 of column modulo(sipHash64(sipHash64(p, toString(toDate(p))), toString(toDate(p))), -0._Float64) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57088) (comment: 02680_illegal_type_of_filter_projection.sql) (in query: SELECT count() FROM test_tuple PREWHERE sipHash64(sipHash64(p, toString(toDate(p))), toString(toDate(p))) % -0. WHERE i > NULL settings optimize_trivial_count_query=0, optimize_use_implicit_projections=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:98: DB::QueryPlanOptimizations::findInOutputs(DB::ActionsDAG&, String const&, bool) @ 0x000000003c19fe51 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:139: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000003c1a05e0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000003c1a077c 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000003c1a077c 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:0: DB::QueryPlanOptimizations::QueryDAG::build(DB::QueryPlan::Node&) @ 0x000000003c1a0ced 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:456: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000003c177e55 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17ed95 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:57.674624 [ 35669 ] {2997defe-f275-49ff-970b-f8daa54f98bc} TCPHandler: Code: 59. DB::Exception: Illegal type Float64 of column modulo(sipHash64(sipHash64(p, toString(toDate(p))), toString(toDate(p))), -0._Float64) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:98: DB::QueryPlanOptimizations::findInOutputs(DB::ActionsDAG&, String const&, bool) @ 0x000000003c19fe51 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:139: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000003c1a05e0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000003c1a077c 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000003c1a077c 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:0: DB::QueryPlanOptimizations::QueryDAG::build(DB::QueryPlan::Node&) @ 0x000000003c1a0ced 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:456: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000003c177e55 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c17ed95 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1002cb 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be8eaba 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8ba0c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:59.079671 [ 35669 ] {ecef6c9c-2239-4bd6-acdf-3892cbe3c92d} executeQuery: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.proto not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57136) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_6xwytcp3-data', Protobuf) select * from numbers(10) settings output_format_schema='../../schema.proto'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:135: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1f479c 5. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowOutputFormat.cpp:64: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b680fe7 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:24:59.084274 [ 35669 ] {ecef6c9c-2239-4bd6-acdf-3892cbe3c92d} TCPHandler: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.proto not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Formats/FormatSchemaInfo.cpp:135: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x000000003b1f479c 5. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowOutputFormat.cpp:64: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x000000003b680fe7 6. ./build_docker/./src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac658aa 7. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac63460 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSink::initialize() @ 0x000000003835f5b7 9. ./build_docker/./src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000003836258b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x0000000038361303 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832dc50 12. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:00.838291 [ 59067 ] {1a674f46-19cf-4e8e-8281-60a4e5b6e046} executeQuery: Code: 48. DB::Exception: DELETE query is not supported for table test_hkp4mp91.users as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57166) (comment: 03161_lightweight_delete_projection.sql) (in query: DELETE FROM users WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6f1a6 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:00.840587 [ 59067 ] {1a674f46-19cf-4e8e-8281-60a4e5b6e046} TCPHandler: Code: 48. DB::Exception: DELETE query is not supported for table test_hkp4mp91.users as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6f1a6 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:00.863772 [ 59067 ] {37a23130-2925-4651-8522-8cc9e29bf270} executeQuery: Code: 48. DB::Exception: DELETE query is not supported for table test_hkp4mp91.users as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57166) (comment: 03161_lightweight_delete_projection.sql) (in query: DELETE FROM users WHERE uid = 8888 SETTINGS lightweight_mutation_projection_mode = 'throw';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6f1a6 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:00.865919 [ 59067 ] {37a23130-2925-4651-8522-8cc9e29bf270} TCPHandler: Code: 48. DB::Exception: DELETE query is not supported for table test_hkp4mp91.users as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6f1a6 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:02.626592 [ 59045 ] {879fbebe-e113-4e8e-905b-a46fe59f5d07} executeQuery: Code: 43. DB::Exception: Nested type LowCardinality(Nullable(String)) cannot be inside Nullable type: In scope SELECT JSONExtract(toNullable('{"string_value":null}'), 'string_value', 'LowCardinality(Nullable(String))') AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57238) (comment: 02013_json_function_null_column.sql) (in query: SELECT JSONExtract(toNullable('{"string_value":null}'), 'string_value', 'LowCardinality(Nullable(String))') as x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::makeNullable(std::shared_ptr const&) @ 0x00000000324451e3 7. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a84f199 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:02.630297 [ 59045 ] {879fbebe-e113-4e8e-905b-a46fe59f5d07} TCPHandler: Code: 43. DB::Exception: Nested type LowCardinality(Nullable(String)) cannot be inside Nullable type: In scope SELECT JSONExtract(toNullable('{"string_value":null}'), 'string_value', 'LowCardinality(Nullable(String))') AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::makeNullable(std::shared_ptr const&) @ 0x00000000324451e3 7. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a84f199 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:02.796068 [ 35669 ] {88120108-cb05-4379-b53c-5eabde0b82b6} executeQuery: Code: 48. DB::Exception: ATTACH ... FROM ... query is not supported for Memory table engine, because such tables do not store any data on disk. Use CREATE instead. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37102) (comment: 01188_attach_table_from_path.sql) (in query: attach table test from 'some/path' (n UInt8) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1695: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d92bc 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:02.798673 [ 35669 ] {88120108-cb05-4379-b53c-5eabde0b82b6} TCPHandler: Code: 48. DB::Exception: ATTACH ... FROM ... query is not supported for Memory table engine, because such tables do not store any data on disk. Use CREATE instead. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1695: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d92bc 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:03.186622 [ 35669 ] {278ed5a7-bc9e-441f-b815-ad91417a2e3f} executeQuery: Code: 481. DB::Exception: Data directory /etc/passwd must be inside /var/lib/clickhouse/user_files/ to attach it. (PATH_ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37102) (comment: 01188_attach_table_from_path.sql) (in query: attach table test from '/etc/passwd' (s String) engine=File(TSVRaw);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1316: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c0b86 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:03.189158 [ 35669 ] {278ed5a7-bc9e-441f-b815-ad91417a2e3f} TCPHandler: Code: 481. DB::Exception: Data directory /etc/passwd must be inside /var/lib/clickhouse/user_files/ to attach it. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1316: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c0b86 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:03.210440 [ 35669 ] {4961a909-b02f-4d84-bbb5-97aa3899a5ea} executeQuery: Code: 481. DB::Exception: Data directory /etc/passwd must be inside /var/lib/clickhouse/user_files/ to attach it. (PATH_ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37102) (comment: 01188_attach_table_from_path.sql) (in query: attach table test from '../../../../../../../../../etc/passwd' (s String) engine=File(TSVRaw);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1316: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c0b86 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:03.212847 [ 35669 ] {4961a909-b02f-4d84-bbb5-97aa3899a5ea} TCPHandler: Code: 481. DB::Exception: Data directory /etc/passwd must be inside /var/lib/clickhouse/user_files/ to attach it. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1316: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c0b86 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:04.053892 [ 59045 ] {252c7952-ea8d-4cbb-8953-4c8bcbb168d8} executeQuery: Code: 43. DB::Exception: The argument 2 of function JSONExtractInt should be a string specifying key or an integer specifying index, illegal type: Nullable(UInt8): In scope SELECT JSONExtractInt('[1]', toLowCardinality(toNullable(1))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57238) (comment: 02013_json_function_null_column.sql) (in query: SELECT JSONExtractInt('[1]', toLowCardinality(toNullable(1)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionJSONHelpers::prepareMoves(char const*, std::vector> const&, unsigned long, unsigned long) @ 0x000000000a7d908c 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000a81db39 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a81cc86 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:25:04.056904 [ 59045 ] {252c7952-ea8d-4cbb-8953-4c8bcbb168d8} TCPHandler: Code: 43. DB::Exception: The argument 2 of function JSONExtractInt should be a string specifying key or an integer specifying index, illegal type: Nullable(UInt8): In scope SELECT JSONExtractInt('[1]', toLowCardinality(toNullable(1))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. DB::FunctionJSONHelpers::prepareMoves(char const*, std::vector> const&, unsigned long, unsigned long) @ 0x000000000a7d908c 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000a81db39 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a81cc86 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008421b22 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:25:04.703970 [ 59045 ] {22f836de-4242-4dea-8204-5ad1ebd3b100} executeQuery: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type: In scope SELECT JSONExtractArrayRaw('["1"]', toNullable(1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57238) (comment: 02013_json_function_null_column.sql) (in query: SELECT JSONExtractArrayRaw('["1"]', toNullable(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::makeNullable(std::shared_ptr const&) @ 0x00000000324451e3 7. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a8764b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:04.707258 [ 59045 ] {22f836de-4242-4dea-8204-5ad1ebd3b100} TCPHandler: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type: In scope SELECT JSONExtractArrayRaw('["1"]', toNullable(1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::makeNullable(std::shared_ptr const&) @ 0x00000000324451e3 7. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a8764b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:05.351727 [ 59045 ] {e263f34e-40b4-4623-9955-298ec40368b9} executeQuery: Code: 43. DB::Exception: Nested type Array(Tuple(String, String)) cannot be inside Nullable type: In scope SELECT JSONExtractKeysAndValuesRaw('["1"]', toNullable(1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57238) (comment: 02013_json_function_null_column.sql) (in query: SELECT JSONExtractKeysAndValuesRaw('["1"]', toNullable(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::makeNullable(std::shared_ptr const&) @ 0x00000000324451e3 7. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a881b19 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:05.354132 [ 59045 ] {e263f34e-40b4-4623-9955-298ec40368b9} TCPHandler: Code: 43. DB::Exception: Nested type Array(Tuple(String, String)) cannot be inside Nullable type: In scope SELECT JSONExtractKeysAndValuesRaw('["1"]', toNullable(1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000324428ed 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x000000002fda7323 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::makeNullable(std::shared_ptr const&) @ 0x00000000324451e3 7. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a881b19 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:06.010681 [ 59045 ] {fdc129eb-24f2-4bec-8a07-642e8e51b49a} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: toNullable(1): In scope SELECT JSONExtractKeysAndValues('["1"]', toNullable(1)). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57238) (comment: 02013_json_function_null_column.sql) (in query: SELECT JSONExtractKeysAndValues('["1"]', toNullable(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. DB::JSONExtractKeysAndValuesImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000a85f75f 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a85ba6e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:06.013956 [ 59045 ] {fdc129eb-24f2-4bec-8a07-642e8e51b49a} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: toNullable(1): In scope SELECT JSONExtractKeysAndValues('["1"]', toNullable(1)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. DB::JSONExtractKeysAndValuesImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000a85f75f 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000a85ba6e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:06.538433 [ 35669 ] {7911bc96-cfc9-456b-aef0-36da58e17499} executeQuery: Code: 48. DB::Exception: Part all_2_2_0 is last inserted part with quorum in partition. Cannot drop. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37166) (comment: 01451_replicated_detach_drop_and_quorum_long.sql) (in query: ALTER TABLE replica1 DETACH PART 'all_2_2_0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::dropPartImpl(std::shared_ptr&, String, DB::ReplicatedMergeTreeLogEntry&, bool, bool) @ 0x000000003893a7a5 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::dropPart(String const&, bool, std::shared_ptr) @ 0x000000003893cc4f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d2aec 7. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:06.541518 [ 35669 ] {7911bc96-cfc9-456b-aef0-36da58e17499} TCPHandler: Code: 48. DB::Exception: Part all_2_2_0 is last inserted part with quorum in partition. Cannot drop. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::dropPartImpl(std::shared_ptr&, String, DB::ReplicatedMergeTreeLogEntry&, bool, bool) @ 0x000000003893a7a5 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::dropPart(String const&, bool, std::shared_ptr) @ 0x000000003893cc4f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397d2aec 7. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348586b0 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:07.834684 [ 1242 ] {0e89c003-db75-4a88-95a6-1a1a63fa6f30::20180101_20180101_1_1_0_3} MutatePlainMergeTreeTask: Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:25:08.178877 [ 1242 ] {0e89c003-db75-4a88-95a6-1a1a63fa6f30::20180101_20180101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1049: DB::MutationContext::checkOperationIsNotCanceled() const @ 0x0000000039ea600d 5. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e65ecf 6. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e65996 7. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3ad7fc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:25:08.989914 [ 59016 ] {7d4827a1-ea74-449f-9b31-692acfc783cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGet doesn't match: passed 4 should be 3: In scope SELECT dictGet('test_dictionary', 'value', 0, 'DefaultValue'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37254) (comment: 02319_dict_get_check_arguments_size.sql) (in query: SELECT dictGet('test_dictionary', 'value', 0, 'DefaultValue');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a8a6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:08.993358 [ 59016 ] {7d4827a1-ea74-449f-9b31-692acfc783cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGet doesn't match: passed 4 should be 3: In scope SELECT dictGet('test_dictionary', 'value', 0, 'DefaultValue'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a8a6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:09.869022 [ 59016 ] {c4b99843-6c86-4271-9639-8e478cdf40cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetOrDefault doesn't match: passed 5 should be 4: In scope SELECT dictGetOrDefault('test_dictionary', 'value', 1, 'DefaultValue', 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37254) (comment: 02319_dict_get_check_arguments_size.sql) (in query: SELECT dictGetOrDefault('test_dictionary', 'value', 1, 'DefaultValue', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096c3d28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:09.872032 [ 59016 ] {c4b99843-6c86-4271-9639-8e478cdf40cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetOrDefault doesn't match: passed 5 should be 4: In scope SELECT dictGetOrDefault('test_dictionary', 'value', 1, 'DefaultValue', 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096c3d28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:10.350211 [ 59016 ] {f9a487cb-4d10-4987-b02a-eade4fef2d76} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGet doesn't match: passed 5 should be 4: In scope SELECT dictGet('range_hashed_dictionary', 'value', 4, toUInt64(6), 'DefaultValue'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37254) (comment: 02319_dict_get_check_arguments_size.sql) (in query: SELECT dictGet('range_hashed_dictionary', 'value', 4, toUInt64(6), 'DefaultValue');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a8a6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:10.363838 [ 59016 ] {f9a487cb-4d10-4987-b02a-eade4fef2d76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGet doesn't match: passed 5 should be 4: In scope SELECT dictGet('range_hashed_dictionary', 'value', 4, toUInt64(6), 'DefaultValue'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a8a6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:10.455684 [ 59016 ] {32e74985-b17b-4b70-9473-d8a2c3ed2357} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetOrDefault doesn't match: passed 6 should be 5: In scope SELECT dictGetOrDefault('range_hashed_dictionary', 'value', 1, toUInt64(6), 'DefaultValue', 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37254) (comment: 02319_dict_get_check_arguments_size.sql) (in query: SELECT dictGetOrDefault('range_hashed_dictionary', 'value', 1, toUInt64(6), 'DefaultValue', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096c3d28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:10.458436 [ 59016 ] {32e74985-b17b-4b70-9473-d8a2c3ed2357} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetOrDefault doesn't match: passed 6 should be 5: In scope SELECT dictGetOrDefault('range_hashed_dictionary', 'value', 1, toUInt64(6), 'DefaultValue', 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&) @ 0x00000000096aecb7 4. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096c3d28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:25:18.637277 [ 58700 ] {d95b9e3f-3ac8-405f-a874-4eba81acb7d1} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT ignore(addHours(now64(3), inf)) FROM numbers(2). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60270) (comment: 01773_datetime64_add_ubsan.sql) (in query: -- The result is unspecified but UBSan should not argue. SELECT ignore(addHours(now64(3), inf)) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b717309 5. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b71061e 6. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b6f2bca 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6edee0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:18.639735 [ 58700 ] {d95b9e3f-3ac8-405f-a874-4eba81acb7d1} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT ignore(addHours(now64(3), inf)) FROM numbers(2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b717309 5. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b71061e 6. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b6f2bca 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6edee0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:19.069306 [ 59039 ] {d2049b1a-cf5f-4e2d-8351-ba00bee2fbf4} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60298) (comment: 02157_readonly_system_suspend.sh) (in query: SYSTEM SUSPEND FOR 1 SECOND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d657f 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d3776 5. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000031292146 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000003372839b 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000035953fbe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:19.072049 [ 59039 ] {d2049b1a-cf5f-4e2d-8351-ba00bee2fbf4} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d657f 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d3776 5. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000031292146 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000003372839b 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000035953fbe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:21.582327 [ 58700 ] {ca593ee5-0b07-44a3-a884-e113a421466e} executeQuery: Code: 69. DB::Exception: Scale 36 is out of bounds (max scale: 18): In scope SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x00000000323758d1 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x0000000018cfd984 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018cf9106 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018c9f43f 8. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018c9bd8c 9. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001861c219 10. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:25:21.586194 [ 58700 ] {ca593ee5-0b07-44a3-a884-e113a421466e} TCPHandler: Code: 69. DB::Exception: Scale 36 is out of bounds (max scale: 18): In scope SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x00000000323758d1 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x0000000018cfd984 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018cf9106 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018c9f43f 8. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018c9bd8c 9. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001861c219 10. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:25:22.406658 [ 58700 ] {a34f671a-bd00-4d19-9b9c-42bb6d4b6be8} executeQuery: Code: 69. DB::Exception: Scale 76 is out of bounds (max scale: 38): In scope SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000032376391 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x0000000018d04ea4 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018d0016e 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018c9f5bd 8. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018c9bd8c 9. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001861c219 10. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:25:22.410210 [ 58700 ] {a34f671a-bd00-4d19-9b9c-42bb6d4b6be8} TCPHandler: Code: 69. DB::Exception: Scale 76 is out of bounds (max scale: 38): In scope SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a88cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000032376391 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x0000000018d04ea4 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018d0016e 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018c9f5bd 8. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018c9bd8c 9. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001861c219 10. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:25:23.743357 [ 58700 ] {b25b39e8-79e7-4869-9e17-3a511b7de711} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION multiply(__table1.h : 0, __table1.h : 0) -> multiply(__table1.h, __table1.h) Decimal(18, 18) : 3'. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT h + h, h - h, h * h, h / h, intDiv(h, h), intDivOrZero(h, h) FROM decimal WHERE h > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)0, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x0000000018893acb 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001888ff12 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::ColumnDecimal>, DB::ColumnDecimal>>(DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018bb2acc 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018bb2012 8. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x0000000018b93ebe 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018b92184 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001895703f 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018946df6 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001893fdc7 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:23.748861 [ 58700 ] {b25b39e8-79e7-4869-9e17-3a511b7de711} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION multiply(__table1.h : 0, __table1.h : 0) -> multiply(__table1.h, __table1.h) Decimal(18, 18) : 3'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)0, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x0000000018893acb 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001888ff12 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::ColumnDecimal>, DB::ColumnDecimal>>(DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018bb2acc 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018bb2012 8. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x0000000018b93ebe 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018b92184 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001895703f 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018946df6 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001893fdc7 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:24.497384 [ 51854 ] {02bb8eb0-22d0-4790-a236-64aa1136e5fe} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53246) (comment: 01073_bad_alter_partition.sql) (in query: ALTER TABLE merge_tree DROP PARTITION '202001-06';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000201d128c 5. ./build_docker/./src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201d0ce8 6. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000961c593 7. ./src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032676fea 8. ./src/IO/ReadBuffer.h:106: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032676e2b 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c1f0b 10. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 11. ./build_docker/./src/Interpreters/convertFieldToType.cpp:620: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c61dd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764145 13. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5030: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bc819 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:24.499875 [ 51854 ] {02bb8eb0-22d0-4790-a236-64aa1136e5fe} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000201d128c 5. ./build_docker/./src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201d0ce8 6. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000961c593 7. ./src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032676fea 8. ./src/IO/ReadBuffer.h:106: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032676e2b 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c1f0b 10. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bbead 11. ./build_docker/./src/Interpreters/convertFieldToType.cpp:620: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c61dd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764145 13. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5030: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000397bc819 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348584c3 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:24.724874 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.727143 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.727571 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.727948 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.728314 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.728714 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.729096 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.729461 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.729844 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.730238 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.730622 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.731034 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.731407 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.732141 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.732526 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.732926 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.733315 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.733706 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.734099 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.734599 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.735107 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.735565 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.736005 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.736405 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.736894 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.737323 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.737728 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.738139 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.738533 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.738967 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.739385 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.739792 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.740240 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.740672 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.741094 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.741500 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.741915 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.742303 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.742699 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.743101 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.743500 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.743906 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.744294 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.744703 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.745093 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.745486 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.745882 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.746292 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.746696 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.747083 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.747525 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.747926 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.748336 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.748765 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.749159 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.749569 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.749977 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.750357 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.750759 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.751161 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.751551 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.751944 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.752328 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.752727 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.753119 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.753506 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.753907 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.754308 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.754702 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.755147 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.755534 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.755931 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.756314 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.756730 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.757116 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.757508 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.757904 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.758291 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.758705 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.759096 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.759479 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.759872 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.760252 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.760652 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.761040 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.761434 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.761832 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.762221 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.762613 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.763027 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.763417 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.763812 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.764195 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.764578 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.764986 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.765366 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.765759 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.766145 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.766520 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.766924 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.767304 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.767689 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.768077 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.768465 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.768902 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.769293 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.769695 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.770081 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.770465 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.770853 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.771232 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.771611 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.772019 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.772392 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.772833 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.773237 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.773636 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.774036 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.774418 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.774822 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.775204 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.775635 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.776026 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.776409 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.776825 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.777208 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.777582 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.777974 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.778383 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.778782 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.779179 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.779572 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.779989 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.780382 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.780790 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.781181 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.781562 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.781960 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.782340 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.782752 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.783148 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.783537 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.783935 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.784317 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.784720 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.785110 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.785502 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.785900 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.786287 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.786681 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.787066 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.787446 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.787837 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.788272 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.788701 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.789092 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.789476 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.789866 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.790253 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.790632 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.791026 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.791412 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.791813 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.792211 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.792602 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.793041 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.793433 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.793835 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.794232 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.794676 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.795066 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.795475 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.795866 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.796252 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.796662 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.797062 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.797450 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.797838 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.798224 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.798606 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.799044 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.799435 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.799837 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.800267 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.800684 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.801076 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.801466 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.801859 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.802254 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.802658 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.805859 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.806256 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.806656 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.807047 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.807459 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.807851 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.808261 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.808685 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.809075 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.809461 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.809851 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.810240 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.810617 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.811010 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.811398 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.811792 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.812182 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.812571 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.812978 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.813367 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.813756 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.814139 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.814517 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.814916 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.815307 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.815698 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.816077 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.816465 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.816880 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.817290 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.817688 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.818075 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.818504 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.818906 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.819325 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.819717 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.820107 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.820496 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.820903 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.821312 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.821716 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.822114 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.822501 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.822944 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.823327 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.823722 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.824105 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.824489 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.824902 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.825296 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.825711 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.826101 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.826518 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.826923 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.827330 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.827798 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.828196 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.828580 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.829013 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.829424 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.829825 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.830212 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.830606 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.831027 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.831418 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.831812 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.832210 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.832588 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.832995 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.833398 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.833793 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.834172 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.834550 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.834964 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.835345 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.835740 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.836127 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.836541 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.836993 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.837445 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.837857 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.838240 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.838626 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.839046 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.839475 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.839907 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.840314 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.840732 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.841122 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.841503 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.841897 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.842280 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.842681 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.843066 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.843446 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.843842 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.844228 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.844625 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.845022 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.845429 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.845861 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.846252 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.846638 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.847035 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.847420 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.847819 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.848230 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.848675 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.849059 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.849448 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.849840 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.850225 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.850599 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.850990 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.851383 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.851777 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.852180 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.852562 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.852979 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.853360 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.853750 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.854129 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.854559 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.855005 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.855391 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.855801 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.856189 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.856574 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.856988 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.857377 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.857784 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.858167 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.858572 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.858972 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.859369 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.859765 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.860151 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.860530 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.860942 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.861363 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.861766 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.862180 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.862568 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.862969 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.863357 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.863752 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.864140 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.864523 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.864928 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.865314 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.865705 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.866097 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.866491 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.866883 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.867272 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.867697 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.868100 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.868523 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.868951 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.869342 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.869746 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.870141 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.870523 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.870921 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.871327 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.871764 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.872145 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.872538 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.872974 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.873371 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.873763 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.874155 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.874537 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.874947 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.875337 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.875725 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.876104 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.876494 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.876916 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.877309 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.877720 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.878123 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.878510 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.878913 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.879302 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.879690 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.880070 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.880479 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.880893 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.881273 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.881674 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.882062 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.882441 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.882825 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.883249 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.883650 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.884048 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.884459 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.884874 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.885269 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.885660 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.886054 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.886436 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.886865 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.887258 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.887676 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.888059 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.888460 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.888932 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.889315 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.889744 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.890129 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.890511 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.890905 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.891282 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.891683 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.892080 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.892470 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.892883 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.893328 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.893741 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.894167 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.894562 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.894970 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.895361 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.895765 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.896150 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.896540 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.896973 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.897375 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.897787 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.898169 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.898584 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.899001 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.899392 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.899813 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.900210 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.900604 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.901028 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.901423 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.901861 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.902258 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.902676 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.903078 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.903508 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.903907 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.904305 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.904744 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.905140 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.905534 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.905933 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.906340 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.906742 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.907147 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.907545 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.907946 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.908342 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.908761 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.909180 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.909574 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.910015 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.910412 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.910819 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.911211 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.911595 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.912014 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.912403 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.912823 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.913220 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.913615 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.914038 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.914424 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.914817 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.915207 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.915596 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.915988 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.916416 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.916921 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.917344 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.917732 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.918116 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.918499 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.918891 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.919310 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.919706 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.920099 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.920484 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.920894 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.921284 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.921690 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.922088 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.922470 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.922893 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.923344 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.923745 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.924127 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.924507 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.924950 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.925336 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.925768 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.926159 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.926598 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.927002 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.927393 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.927786 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.928181 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.928584 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.928998 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.929385 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.929774 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.930158 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.930534 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.930925 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.931308 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.931697 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.932097 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.932479 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.932895 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.933290 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.933692 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.934076 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.934460 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.934867 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.935252 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.935632 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.936046 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.936433 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.936847 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.937249 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.937635 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.938029 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.938416 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.938892 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.939375 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.939881 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.940286 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.940716 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.941105 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.941483 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.941924 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.942338 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.942734 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.943143 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.943532 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.943959 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.944344 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.944763 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.945164 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.945560 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.945999 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.946386 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.946781 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.947171 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.947562 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.947958 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.948340 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.948807 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.949206 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.949593 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.949995 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.950372 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.950769 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.951148 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.951532 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.951927 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.952317 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.952729 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.953117 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.953510 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.953905 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.954288 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.954687 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.955100 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.955478 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.955866 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.956250 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.956680 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.957120 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.957503 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.957899 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.958297 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.958735 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.959142 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.959562 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.960057 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.960458 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.960873 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.961259 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.961651 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.962030 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.962409 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.962796 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.963172 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.963555 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.963947 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.964353 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.964767 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.965154 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.965531 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.965920 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.966299 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.966688 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.967063 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.967436 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.967828 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.968221 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.968668 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.969054 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.969440 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.969833 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.970220 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.970603 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.971017 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.971472 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.971978 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.972465 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.972986 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.973408 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.973914 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.974435 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.974942 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.975463 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.975926 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.976331 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.976757 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.977231 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.977707 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.978153 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.978553 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.978950 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.979394 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.979923 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.980448 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.981010 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.981561 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.982111 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.982640 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.983180 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.983734 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.984244 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.984668 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.985054 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.985444 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.990607 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.991117 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.991602 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.992165 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.992584 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.993092 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.993583 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.994790 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:24.998750 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:25.004119 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv1 (897ff271-952f-4a46-83eb-08adb6764c60), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:25.009605 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} PushingToViews: Failed to push block to view test_3q1bjvrt.mv2 (11d06ea9-1bee-4ff0-83a9-9fef501e3b70), Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608 2025.06.18 11:25:25.623932 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53244) (comment: 00986_materialized_view_stack_overflow.sql) (in query: insert into test1 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000201528ff 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000201524aa 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399203d 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:962: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7ada 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000335a1b4d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476209 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dbdff 10. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce485f 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba63c58 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000034b934ce 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba6780d 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000034b934ce 25. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba6780d 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 27. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 28. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000034b934ce 29. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba6780d 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 31. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 2025.06.18 11:25:25.626938 [ 58685 ] {e68bac06-2b4c-41e3-a311-f0e6162d8c57} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f892f006000, frame address: 0x7f892f405930, stack size: 4196048, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000201528ff 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000201524aa 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399203d 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:962: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7ada 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000335a1b4d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476209 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dbdff 10. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce485f 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba63c58 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000034b934ce 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba6780d 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000034b934ce 25. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba6780d 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 27. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 28. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000034b934ce 29. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003ba6780d 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba70499 31. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 2025.06.18 11:25:25.844141 [ 58700 ] {abff32e6-d7b0-4ee2-bec9-f2a9297c338c} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.e : 0, 21_UInt8 : 1) -> plus(__table1.e, 21_UInt8) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT e + 21, e - 21, e - 84, e * 21, e * -21, e / 21, e / 84 FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, long>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019f452f9 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a322dc4 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a321dd0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a31b283 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a0aa3bf 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a09a176 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a092bf0 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a08e47c 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:25.850209 [ 58700 ] {abff32e6-d7b0-4ee2-bec9-f2a9297c338c} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.e : 0, 21_UInt8 : 1) -> plus(__table1.e, 21_UInt8) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, long>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019f452f9 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a322dc4 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a321dd0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a31b283 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a0aa3bf 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a09a176 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a092bf0 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a08e47c 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:28.398954 [ 58700 ] {dbbda648-7b8b-4da0-ad94-ab4d2bf497c8} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(21_UInt8 : 1, __table1.e : 0) -> plus(21_UInt8, __table1.e) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 21 + e, 21 - e, 84 - e, 21 * e, -21 * e, 21 / e, 84 / e FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019cc6f03 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a0cd16b 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a0cc330 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001a0b027e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a0ae544 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a0a9126 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a09a176 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a092bf0 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a08e47c 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:28.404555 [ 58700 ] {dbbda648-7b8b-4da0-ad94-ab4d2bf497c8} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(21_UInt8 : 1, __table1.e : 0) -> plus(21_UInt8, __table1.e) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019cc6f03 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a0cd16b 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a0cc330 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001a0b027e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a0ae544 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a0a9126 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a09a176 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a092bf0 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a08e47c 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:29.108421 [ 51854 ] {42786245-3c25-4cb0-bbf1-150e21f35069} executeQuery: Code: 80. DB::Exception: Query from view test_fhk935k4.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53284) (comment: 01866_view_persist_settings.sql) (in query: SELECT * FROM view_no_nulls;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageView.cpp:196: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038cb8422 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:29.111338 [ 51854 ] {42786245-3c25-4cb0-bbf1-150e21f35069} TCPHandler: Code: 80. DB::Exception: Query from view test_fhk935k4.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageView.cpp:196: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038cb8422 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:30.022976 [ 58700 ] {b09b8790-e214-49c0-80a7-fc7fb2043d8e} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION divide(21_UInt8 :: 1, __table1.h : 0) -> divide(21_UInt8, __table1.h) Decimal(18, 9) : 7'. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 21 + h, 21 - h, 84 - h, 21 * h, -21 * h, 21 / h, 84 / h FROM decimal WHERE h > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)1, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000000dfc618e 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000dfc5784 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b3750 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b2910 8. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000e69657e 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e694844 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 13. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:30.027888 [ 58700 ] {b09b8790-e214-49c0-80a7-fc7fb2043d8e} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION divide(21_UInt8 :: 1, __table1.h : 0) -> divide(21_UInt8, __table1.h) Decimal(18, 9) : 7'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)1, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000000dfc618e 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000dfc5784 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b3750 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b2910 8. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000e69657e 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e694844 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 13. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:31.480677 [ 51854 ] {5c22f297-d25f-4ec3-b891-14852a77b71f} executeQuery: Code: 80. DB::Exception: Query from view test_fhk935k4.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53284) (comment: 01866_view_persist_settings.sql) (in query: SELECT * FROM view_no_nulls;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageView.cpp:196: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038cb8422 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:31.484014 [ 51854 ] {5c22f297-d25f-4ec3-b891-14852a77b71f} TCPHandler: Code: 80. DB::Exception: Query from view test_fhk935k4.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageView.cpp:196: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038cb8422 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:32.219467 [ 58700 ] {dbee4a52-734f-4ad7-8c93-7086c80debcd} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal32(0, 0). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 1 / toDecimal32(0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000dfbf271 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b12e1 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b02f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6945bd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:32.223325 [ 58700 ] {dbee4a52-734f-4ad7-8c93-7086c80debcd} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal32(0, 0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000dfbf271 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b12e1 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b02f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6945bd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:33.129270 [ 1391 ] {3fa23c18-03e9-4055-9051-0e8b9b824421} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 47f3590c-f722-47bc-8b41-6da3cbb2b0f3. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:33.149784 [ 58700 ] {028e2241-b084-4ad5-b795-51b688ee5588} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal64(0, 1). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 1 / toDecimal64(0, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000dfc4703 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b3920 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b2910 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000e69657e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e694844 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:33.153220 [ 58700 ] {028e2241-b084-4ad5-b795-51b688ee5588} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal64(0, 1). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000dfc4703 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b3920 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b2910 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000e69657e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e694844 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:33.870466 [ 1391 ] {bc0b1b0c-9c3e-4779-abec-e9242f430cd1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 7cb269c8-85e5-4599-8292-f7ef76b536d8. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:33.871775 [ 1391 ] {bc0b1b0c-9c3e-4779-abec-e9242f430cd1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id eea3b5ee-15fb-4c30-95d6-a60d87852883. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:34.010192 [ 58700 ] {86ee1b3a-cebc-4c87-91ff-82a61ec130a4} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal128(0, 2). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 1 / toDecimal128(0, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfca8f2 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfcad82 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b634b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b4f90 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6949fd 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:34.013692 [ 58700 ] {86ee1b3a-cebc-4c87-91ff-82a61ec130a4} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal128(0, 2). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfca8f2 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfcad82 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b634b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b4f90 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6949fd 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:34.045970 [ 58700 ] {2128478d-c560-4bf9-88d1-f4c475820df2} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal32(0, 3). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 0 / toDecimal32(0, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000dfbf271 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b12e1 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b02f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6945bd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:34.047514 [ 1395 ] {1b918ca6-f17c-44ee-a768-59b0403569df} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 05dc94af-421d-48c9-ba51-5f46b036b6c5. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:34.048407 [ 58700 ] {2128478d-c560-4bf9-88d1-f4c475820df2} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal32(0, 3). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000dfbf271 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b12e1 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b02f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6945bd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:34.079856 [ 58700 ] {5a1e9880-1b8e-4f26-93df-0451dd7afd0d} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal64(0, 4). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 0 / toDecimal64(0, 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000dfc4703 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b3920 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b2910 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000e69657e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e694844 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:34.082318 [ 58700 ] {5a1e9880-1b8e-4f26-93df-0451dd7afd0d} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal64(0, 4). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000dfc4703 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b3920 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b2910 7. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000e69657e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e694844 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:34.116493 [ 58700 ] {c4264749-d640-406c-b392-c5b25c7104f1} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal128(0, 5). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT 0 / toDecimal128(0, 5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfca8f2 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfcad82 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b634b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b4f90 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6949fd 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:34.119179 [ 58700 ] {c4264749-d640-406c-b392-c5b25c7104f1} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal128(0, 5). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfca8f2 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfcad82 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b634b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e6b4f90 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6949fd 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e68f426 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 14. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 2025.06.18 11:25:34.390708 [ 1402 ] {06c44a27-8440-4894-8c91-ee5ea9ceac0e} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9c23b52e-5032-4918-a4cb-c181af278c83. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:34.917461 [ 1395 ] {d47773e8-d3d7-4011-9cc0-7204edec508a} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 11c45b62-80e6-4818-9a54-a0605e1c0a53. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:34.964337 [ 58700 ] {b8db8509-33bf-4eb4-9091-89ea56f3a101} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal32(0, 0) / toInt8(0). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT toDecimal32(0, 0) / toInt8(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000dfbf271 5. _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000000e8d79f8 6. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e8d6e10 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e8c43fd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e69055d 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:34.967497 [ 58700 ] {b8db8509-33bf-4eb4-9091-89ea56f3a101} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal32(0, 0) / toInt8(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000dfbf271 5. _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000000e8d79f8 6. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e8d6e10 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e8c43fd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e69055d 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:35.338577 [ 1395 ] {2daa666b-7539-430e-92e3-f36eb064456c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 159c6b07-7ccd-4cb7-bb15-a5825b2bff66. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:35.821437 [ 58700 ] {38898f6f-58c1-4896-aaa8-89ea5373d4e1} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal64(0, 1) / toInt32(0). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT toDecimal64(0, 1) / toInt32(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000dfc4703 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e90bf78 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e90b390 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e8f47bd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6906bf 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:35.825035 [ 58700 ] {38898f6f-58c1-4896-aaa8-89ea5373d4e1} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal64(0, 1) / toInt32(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000dfc4703 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e90bf78 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e90b390 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e8f47bd 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e6906bf 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:36.691136 [ 58700 ] {af90fd21-8537-4676-b50b-61cbb3d5c991} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal128(0, 2) / toInt64(0). (ILLEGAL_DIVISION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT toDecimal128(0, 2) / toInt64(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfca8f2 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e942eaf 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e941bd0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e924bef 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e69083d 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:36.694433 [ 58700 ] {af90fd21-8537-4676-b50b-61cbb3d5c991} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal128(0, 2) / toInt64(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dfca8f2 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e942eaf 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e941bd0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e924bef 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e69083d 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e680476 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e67af6b 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6776bc 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 2025.06.18 11:25:36.912467 [ 1402 ] {b2b9680e-3849-47fd-91f7-817c9deefecb} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id f4d79d68-cd36-4dfc-9f91-17c555cdeb84. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:37.399514 [ 1395 ] {dfb481a9-e116-465f-96d3-19530783eae9} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9e475fed-838a-4d52-8268-7857cddb39ea. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:37.996768 [ 58700 ] {98493ecf-1e27-4d12-93d1-174ba5c5a32f} executeQuery: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000ea8db9c 5. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea8820e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea22ddd 7. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea1f43f 8. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 9. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:25:38.000186 [ 58700 ] {98493ecf-1e27-4d12-93d1-174ba5c5a32f} TCPHandler: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000ea8db9c 5. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea8820e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea22ddd 7. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea1f43f 8. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 9. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:25:38.281753 [ 58700 ] {110162f3-e4ff-4cee-88b9-4a97af26a6a1} executeQuery: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60324) (comment: 00700_decimal_arithm.sql) (in query: SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000ea8db9c 5. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea8820e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea22ddd 7. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea1f43f 8. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 9. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:25:38.284953 [ 58700 ] {110162f3-e4ff-4cee-88b9-4a97af26a6a1} TCPHandler: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000ea8db9c 5. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea8820e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000ea22ddd 7. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000ea1f43f 8. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df739d9 9. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a7c92c3 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:25:39.172160 [ 1402 ] {7871a685-57f9-4e92-9a53-ba35d9b425a4} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 18a451e7-27fc-45d9-846f-2603ca2f9f2e. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:39.773857 [ 1391 ] {04877844-ff1c-43e0-bef3-2cdce20e7442} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 23b0c66b-1c31-4ed2-bb3b-c37236893b4f. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:39.951615 [ 1402 ] {3c8d3a39-3e52-4891-8918-c768d244f732} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 01820535-ba0e-4af6-95f9-5b031c49c494. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:40.434663 [ 1402 ] {5236a76a-f387-4fb1-b32b-34f4211cafd3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9203f024-4f69-4ef4-ad65-60530340a0ed. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:41.229145 [ 1395 ] {b39a7bf6-ef11-4582-9120-5e5c81281302} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 4953a4e7-a281-4997-b4f8-6514bb61a830. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:42.541887 [ 1402 ] {97650ed5-3476-4ee5-8cc4-3299800ec136} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id bdc39846-58df-432b-902e-05dc73ab838f. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:42.667032 [ 1391 ] {2f0fef6d-5a3f-41e7-b341-e53e8235c385} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 3c127d9d-eb93-490c-b43b-a3d4f6c3bbd1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:43.397946 [ 1391 ] {c764837e-e419-4d2d-be4c-b73b22616957} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 5207e9d3-0ebf-40e9-ab9c-4eea874913f0. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:44.271426 [ 59082 ] {c80e013a-82e1-43d1-859a-db5ca9568d93} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1, untuple(CAST(tuple(1), 'Tuple(a Int)')). (DUPLICATE_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60236) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(a Int)), untuple(tuple(1)::Tuple(a Int)) FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:44.273340 [ 1402 ] {16268d84-d270-40ae-bb28-9448d13853ad} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9e3d0718-dbb5-4b92-abd3-a4db668754a4. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:44.274120 [ 59082 ] {c80e013a-82e1-43d1-859a-db5ca9568d93} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1, untuple(CAST(tuple(1), 'Tuple(a Int)')). (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:44.547389 [ 1395 ] {eae967de-a248-468a-b8c7-2653defec7d9} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id cd2c19a9-4f4a-478e-81b8-19e1259fed0d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:44.592730 [ 59082 ] {90be7eae-b116-4720-80ab-5a106e2c08aa} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1 AS `x.a`, untuple(CAST(tuple(1), 'Tuple(a Int)')) AS x. (DUPLICATE_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60236) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(a Int)) x, untuple(tuple(1)::Tuple(a Int)) x FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:44.595433 [ 59082 ] {90be7eae-b116-4720-80ab-5a106e2c08aa} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1 AS `x.a`, untuple(CAST(tuple(1), 'Tuple(a Int)')) AS x. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:44.963976 [ 59082 ] {38293cad-1c14-4417-aab1-307661dd425b} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1 AS `x.1`, untuple(CAST(tuple(1), 'Tuple(Int)')) AS x. (DUPLICATE_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60236) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(Int)) x, untuple(tuple(1)::Tuple(Int)) x FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:44.967290 [ 59082 ] {38293cad-1c14-4417-aab1-307661dd425b} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1 AS `x.1`, untuple(CAST(tuple(1), 'Tuple(Int)')) AS x. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:45.300742 [ 1402 ] {dc8394f2-864c-42ad-af8f-029589756d99} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 5e72b121-add3-4182-abe0-4e20b2ac5549. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:45.345577 [ 59082 ] {df56d56c-fa18-4dcd-afd6-a976e6173350} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1, untuple(CAST(tuple(1), 'Tuple(Int)')). (DUPLICATE_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60236) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(Int)), untuple(tuple(1)::Tuple(Int)) FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:45.349225 [ 59082 ] {df56d56c-fa18-4dcd-afd6-a976e6173350} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1, untuple(CAST(tuple(1), 'Tuple(Int)')). (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:468: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000033b2d55d 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b0a020 6. ./src/Interpreters/ActionsVisitor.h:0: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000033b23a74 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:374: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2056b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0bbf5 9. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 10. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000033a92c65 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000033aa49f2 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000034c1b06c 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000034bf9c99 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034be4d30 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bd7f51 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000034e4b559 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034e45dee 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034e5aace 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:419: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034e53e13 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 31. ? @ 0x00007f8e6ce63ac3 2025.06.18 11:25:46.248427 [ 1402 ] {cf22fa6f-3c93-49d3-b7c5-fff8615511dd} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 73334b6b-670b-439f-9e46-f436a393f177. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:46.352436 [ 1391 ] {f191454f-b3ec-4e66-ab22-f1b3a076d5f2} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 4d6394df-3bbe-46fc-b883-3f0eb2d84a4d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:48.694067 [ 1395 ] {3eb86fdb-8c82-4a6a-8c17-54e1a992b2b5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 16a9d56d-7e52-451e-854b-572a02ef86cf. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:49.191560 [ 35047 ] {e9b167a8-3671-4303-937a-c2bf4b9f6011} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60394) (comment: 02465_limit_trivial_max_rows_to_read.sql) (in query: SELECT number FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:49.194666 [ 35047 ] {e9b167a8-3671-4303-937a-c2bf4b9f6011} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:49.264499 [ 35047 ] {5b812f69-8b4c-40ce-a065-4f2ef2cc77b2} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60394) (comment: 02465_limit_trivial_max_rows_to_read.sql) (in query: SELECT number FROM numbers(30) LIMIT 21;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:49.267773 [ 35047 ] {5b812f69-8b4c-40ce-a065-4f2ef2cc77b2} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:623: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c0970af 7. ./src/QueryPipeline/Pipe.h:45: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c093151 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:49.578359 [ 35047 ] {fc9c3713-a7ae-4060-940e-83d4cb9a2273} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60394) (comment: 02465_limit_trivial_max_rows_to_read.sql) (in query: SELECT a FROM t_max_rows_to_read LIMIT 11 offset 11;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:49.581914 [ 35047 ] {fc9c3713-a7ae-4060-940e-83d4cb9a2273} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:49.668930 [ 35047 ] {0ffa5108-408f-457b-b721-6159b7d1e356} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 52.00. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60394) (comment: 02465_limit_trivial_max_rows_to_read.sql) (in query: SELECT a FROM t_max_rows_to_read WHERE a > 50 LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:49.672767 [ 35047 ] {0ffa5108-408f-457b-b721-6159b7d1e356} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 52.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000032353c4c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf19009 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be1dcc3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8c2e5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce530d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce4d21 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:51.136084 [ 1395 ] {913030fa-3508-47c2-8c36-ee40cfd0a149} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9377067c-5ccf-4c6d-8200-ce505c864676. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:51.550746 [ 1395 ] {45473d26-3adf-4828-90e8-ee6174ee975a} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 0379471c-4594-44bb-9fff-16559c7fc88a. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:51.551626 [ 1395 ] {45473d26-3adf-4828-90e8-ee6174ee975a} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 2322c966-9d1f-473b-93f4-b5d7bd1628ce. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:52.159335 [ 1395 ] {65d60dd5-6203-47ac-803c-451a0799b00f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id a90b3c6a-8c5b-467d-aff0-aa4b9950b8eb. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:52.160466 [ 1395 ] {65d60dd5-6203-47ac-803c-451a0799b00f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id d032feba-3669-478d-9a20-2061f9fb28e6. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:52.161124 [ 1395 ] {65d60dd5-6203-47ac-803c-451a0799b00f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 59339273-882f-4677-93e2-996b44f32c27. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:52.190331 [ 51854 ] {80fd793d-b249-4acb-b011-fe5046f3a3d5} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/test_714memsc/test/replicas/replica-92427cc0-299d-4553-b6c7-a452802d57ca already exists. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60492) (comment: 02711_server_uuid_macro.sql) (in query: CREATE TABLE test2 (`x` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test', 'replica-{server_uuid}') ORDER BY x SETTINGS index_granularity = 11745, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 417415053, compact_parts_max_granules_to_buffer = 217, compact_parts_merge_max_bytes_to_prefetch_part = 16201581, merge_max_block_size = 20660, old_parts_lifetime = 252., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 14482199, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67550, primary_key_compress_block_size = 52300), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x0000000038711a79 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:560: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386dd04b 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2c265e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2013 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:52.194227 [ 51854 ] {80fd793d-b249-4acb-b011-fe5046f3a3d5} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/test_714memsc/test/replicas/replica-92427cc0-299d-4553-b6c7-a452802d57ca already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x0000000038711a79 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:560: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386dd04b 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2c265e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b2013 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:53.042072 [ 51854 ] {dbaa30f8-60b5-4bb3-a664-ac0080bc46b8} executeQuery: Code: 139. DB::Exception: No macro server_uuid in config: In scope SELECT getMacro('server_uuid'). (NO_ELEMENTS_IN_CONFIG) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60492) (comment: 02711_server_uuid_macro.sql) (in query: -- The macro {server_uuid} is special, not a configuration-type macro. It's normal that it is inaccessible with the getMacro function. SELECT getMacro('server_uuid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Common/Macros.cpp:168: DB::Macros::getValue(String const&) const @ 0x000000002008be48 5. DB::(anonymous namespace)::FunctionGetMacro::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe8ea42 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:25:53.044998 [ 51854 ] {dbaa30f8-60b5-4bb3-a664-ac0080bc46b8} TCPHandler: Code: 139. DB::Exception: No macro server_uuid in config: In scope SELECT getMacro('server_uuid'). (NO_ELEMENTS_IN_CONFIG), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Common/Macros.cpp:168: DB::Macros::getValue(String const&) const @ 0x000000002008be48 5. DB::(anonymous namespace)::FunctionGetMacro::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe8ea42 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:25:53.842410 [ 1402 ] {ae25c53a-89f1-443f-bb34-4a5ae7921f14} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 5f3b5cf3-3b4d-43b2-a4c2-28cd2e84dec1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:53.843450 [ 1402 ] {ae25c53a-89f1-443f-bb34-4a5ae7921f14} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id d4b0f403-0437-4783-adbd-9544de7fb2a3. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:54.231685 [ 58700 ] {21fa3ccb-b41c-4570-9dab-5ac536f8c640} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/d0e/d0ed0449-4e1c-4cbd-9eb9-67cb754f5da2//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46562) (comment: 01720_engine_file_empty_if_not_exists.sql) (in query: SELECT * FROM file_engine_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:54.235016 [ 58700 ] {21fa3ccb-b41c-4570-9dab-5ac536f8c640} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/d0e/d0ed0449-4e1c-4cbd-9eb9-67cb754f5da2//data.TSV doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:54.307885 [ 58700 ] {a5c3c470-7e71-4154-ba6a-5c4a210ee6ac} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/d0e/d0ed0449-4e1c-4cbd-9eb9-67cb754f5da2//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46562) (comment: 01720_engine_file_empty_if_not_exists.sql) (in query: SELECT * FROM file_engine_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:54.312847 [ 58700 ] {a5c3c470-7e71-4154-ba6a-5c4a210ee6ac} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/d0e/d0ed0449-4e1c-4cbd-9eb9-67cb754f5da2//data.TSV doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038328042 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:25:54.423892 [ 1391 ] {0ae711e9-4fe1-4466-a659-a307fd3b6da3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 0d40a568-c294-4de6-bdba-5a8f8843004d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:54.681857 [ 1402 ] {e2d81421-c9c0-43d4-8d60-fb5a417fd159} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 39c90647-6c60-4a0c-9932-3ed3285a8c8d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:56.027455 [ 1402 ] {f95dd4e2-d9a5-410e-920f-fc44cb57f90b} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 40144dc9-ec8e-4f3f-8559-f37a50b7e75b. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:56.028787 [ 1402 ] {f95dd4e2-d9a5-410e-920f-fc44cb57f90b} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 7efdd08b-3836-4c3d-a593-d44f803c0299. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:57.610046 [ 1391 ] {e6402686-f0c7-4e6e-85c6-18b9e3223340} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 0f036ce6-cd69-4f2b-b784-fce43c68c9ab. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:59.291628 [ 1402 ] {7e2149bb-a6fc-4d38-a0a9-c1e9cbb0f484} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 10aedf8e-ea71-49ff-a343-2e7040a8c6ff. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:25:59.293010 [ 1402 ] {7e2149bb-a6fc-4d38-a0a9-c1e9cbb0f484} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 07dff7e9-f167-4545-b7b4-7352feb0bb98. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:00.853349 [ 1391 ] {6c0e5f3b-ff85-41b1-8850-32b85fbb7e0d} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 69e8d09b-6eb3-4be5-9305-bba21cddc3b1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:02.383423 [ 1402 ] {45e7c94f-c7f3-400f-9e40-e7b2618fc59f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1f333c30-5140-4baa-a3af-a20c1ee46c1a. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:02.386535 [ 1402 ] {45e7c94f-c7f3-400f-9e40-e7b2618fc59f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9463fc7b-932f-4b3c-8d54-cef20d406350. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:02.387767 [ 1402 ] {45e7c94f-c7f3-400f-9e40-e7b2618fc59f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 726e7afd-74c4-4773-8e46-7306b786fdee. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:02.389809 [ 1402 ] {45e7c94f-c7f3-400f-9e40-e7b2618fc59f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9fd4015e-56eb-4a39-a20b-75eea7b1766b. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:03.873772 [ 1402 ] {ac5f6ae5-34e6-44e0-a4da-9aefde8b6578} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id c95a53fa-1b2f-469d-ae67-18a6308b0262. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:03.875548 [ 1402 ] {ac5f6ae5-34e6-44e0-a4da-9aefde8b6578} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 95de6392-1397-498f-9507-eb64141c6b90. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:03.876501 [ 1402 ] {ac5f6ae5-34e6-44e0-a4da-9aefde8b6578} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id fb07c259-6242-4959-b40a-85c64ccac01f. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:05.090166 [ 35047 ] {68351353-f7f6-4422-9b31-665ed2148b6e} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46688) (comment: 02269_to_start_of_interval_overflow.sql) (in query: select toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7031fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6ff03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6faec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6fa2e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f8e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:26:05.093112 [ 35047 ] {68351353-f7f6-4422-9b31-665ed2148b6e} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7031fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6ff03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6faec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6fa2e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f8e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:26:05.184671 [ 35047 ] {902f48cd-55d8-4af7-80d8-f021c603dacf} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46688) (comment: 02269_to_start_of_interval_overflow.sql) (in query: SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7031fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6ff03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6faec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6fa2e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f8e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:26:05.188112 [ 35047 ] {902f48cd-55d8-4af7-80d8-f021c603dacf} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7031fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6ff03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6faec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6fa2e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f8e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 2025.06.18 11:26:06.879805 [ 35047 ] {3d40db63-6f6a-444e-bf86-f586e7635458} executeQuery: Code: 215. DB::Exception: Column r.a is not under aggregate function and not in GROUP BY keys. In query SELECT v.x, r.a, sum(c) FROM (SELECT 1 AS x, 2 AS c) AS v ANY LEFT JOIN (SELECT 1 AS x, 2 AS a) AS r ON v.x = r.x GROUP BY v.x. (NOT_AN_AGGREGATE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46742) (comment: 03126_column_not_under_group_by.sql) (in query: SELECT v.x, r.a, sum(c) FROM (select 1 x, 2 c) AS v ANY LEFT JOIN (SELECT 1 x, 2 a) AS r ON v.x = r.x GROUP BY v.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:06.884221 [ 35047 ] {3d40db63-6f6a-444e-bf86-f586e7635458} TCPHandler: Code: 215. DB::Exception: Column r.a is not under aggregate function and not in GROUP BY keys. In query SELECT v.x, r.a, sum(c) FROM (SELECT 1 AS x, 2 AS c) AS v ANY LEFT JOIN (SELECT 1 AS x, 2 AS a) AS r ON v.x = r.x GROUP BY v.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033589a47 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033588ce2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033587088 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e7b2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:07.060151 [ 1402 ] {e5b50faf-cd63-460f-a87d-df2247295fe5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id e12e6d77-79ca-4c4f-b790-cf19627e16c5. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:07.061849 [ 1402 ] {e5b50faf-cd63-460f-a87d-df2247295fe5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 5e87bf94-4eab-4b8e-9bcb-9e4c68980519. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:07.062888 [ 1402 ] {e5b50faf-cd63-460f-a87d-df2247295fe5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 15cd6b31-f7c2-4f99-a274-0f6d49b85d99. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:10.252236 [ 1395 ] {d3417545-5334-4e66-9e56-93d365e39110} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id a262360b-f4f0-491a-9c6c-e66a7694ffea. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:10.254073 [ 1395 ] {d3417545-5334-4e66-9e56-93d365e39110} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 38f7f036-ca45-4e79-9e59-6eb39c73ffe4. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:11.825897 [ 1391 ] {7b240b99-1aba-4a8e-a002-be2a5bc66862} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1e9394ea-dfa5-45dd-8c1b-991cd14604c3. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:11.827874 [ 1391 ] {7b240b99-1aba-4a8e-a002-be2a5bc66862} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 49c9c069-17a5-4340-971f-8e608a3f3ae1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:11.829556 [ 1391 ] {7b240b99-1aba-4a8e-a002-be2a5bc66862} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 80a730f6-6d12-4845-aba2-27890b94e14d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:13.255090 [ 35673 ] {4020e910-18c9-45e5-a66b-def6685ddf7e} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE now(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::NowOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019acb50d 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:13.260019 [ 35673 ] {4020e910-18c9-45e5-a66b-def6685ddf7e} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::NowOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019acb50d 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:13.340127 [ 1395 ] {54874a7a-1500-4ea2-b103-a5a800c89ddb} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 8fdebaeb-f098-4962-bc4f-8181fcc23873. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:13.342604 [ 1395 ] {54874a7a-1500-4ea2-b103-a5a800c89ddb} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 09fafbf4-6a80-4d16-af2d-823bd74edf34. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:13.343858 [ 1395 ] {54874a7a-1500-4ea2-b103-a5a800c89ddb} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id b2897eef-debf-49b4-975f-0ea3af7b659d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:13.344764 [ 1395 ] {54874a7a-1500-4ea2-b103-a5a800c89ddb} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1bde8688-e31b-4c8c-b6c1-73bcc88cfcdc. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:13.345710 [ 1395 ] {54874a7a-1500-4ea2-b103-a5a800c89ddb} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 08002974-c43e-4d2a-9e4a-b57e4acf9b1d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:14.232039 [ 35673 ] {ff403dc9-2c84-43cf-a004-b76ce3f9587b} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now64(9, tz) != toDateTime64('2000-01-01 00:00:00', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE now64(9, tz) != toDateTime64('2000-01-01 00:00:00', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019acf9ff 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:14.236169 [ 35673 ] {ff403dc9-2c84-43cf-a004-b76ce3f9587b} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now64(9, tz) != toDateTime64('2000-01-01 00:00:00', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019acf9ff 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:14.973341 [ 1402 ] {5c120e93-141c-4701-b8ef-9c0e9f3b02ba} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 57ac555e-ed31-42c0-b052-2a350816ef92. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:15.283704 [ 35673 ] {c46d08d3-cbe1-447f-a2d7-a4ac1ccfb126} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE nowInBlock(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE nowInBlock(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad38ad 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:15.291193 [ 35673 ] {c46d08d3-cbe1-447f-a2d7-a4ac1ccfb126} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE nowInBlock(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad38ad 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:16.298476 [ 35673 ] {25f34da3-67dd-4ad2-9086-a64a91f7b22b} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE toTimeZone(toDateTime(val), tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE toTimeZone(toDateTime(val), tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::ToTimeZoneOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c762442 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:16.302435 [ 35673 ] {25f34da3-67dd-4ad2-9086-a64a91f7b22b} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE toTimeZone(toDateTime(val), tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::ToTimeZoneOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c762442 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:16.465103 [ 1395 ] {1bcb951c-9ae6-4aef-b014-213de7825bb8} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id e0fe1a10-8757-4b00-8f17-5c8c8a031b4f. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:16.466378 [ 1395 ] {1bcb951c-9ae6-4aef-b014-213de7825bb8} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id bae7b2e3-98a4-4d87-a6c8-1e4485cb49f3. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:16.466994 [ 1395 ] {1bcb951c-9ae6-4aef-b014-213de7825bb8} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 800c9d96-13f5-49ad-b162-086595a64271. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:17.333241 [ 35673 ] {1e2773d0-007b-45f1-b0bc-88d89d614d6c} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Milli(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE fromUnixTimestamp64Milli(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008459022 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:17.337467 [ 35673 ] {1e2773d0-007b-45f1-b0bc-88d89d614d6c} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Milli(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008459022 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:17.528113 [ 35673 ] {fcb7a900-03b9-4f59-9a9e-479be4894524} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Micro(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE fromUnixTimestamp64Micro(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008459022 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:17.531450 [ 35673 ] {fcb7a900-03b9-4f59-9a9e-479be4894524} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Micro(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008459022 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:17.670314 [ 35674 ] {039b28cc-c08a-400d-9a4e-71ff2f1d5357} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toDayOfWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34790) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toDayOfWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e3007 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcd22 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:26:17.673938 [ 35674 ] {039b28cc-c08a-400d-9a4e-71ff2f1d5357} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toDayOfWeek('invalid'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e3007 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcd22 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:26:17.744229 [ 35673 ] {102ab2c7-d457-4828-bc23-f7047ededc9c} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Nano(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE fromUnixTimestamp64Nano(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008459022 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:17.747405 [ 35673 ] {102ab2c7-d457-4828-bc23-f7047ededc9c} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Nano(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008459022 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:18.084358 [ 1402 ] {1223cb04-28a7-4f96-99a5-68b03b91abc5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id f44da119-56dc-4590-ae2c-7896a073a6d1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:18.085615 [ 1402 ] {1223cb04-28a7-4f96-99a5-68b03b91abc5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id a6db81ca-3828-4496-a359-a6c2cb5a28c6. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:18.086784 [ 1402 ] {1223cb04-28a7-4f96-99a5-68b03b91abc5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 85aab15b-c8df-4980-b31c-7f45d0bd5ed4. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:18.087756 [ 1402 ] {1223cb04-28a7-4f96-99a5-68b03b91abc5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9a1543ca-5823-48a0-b6ac-1fa38d1d641e. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:18.088426 [ 1402 ] {1223cb04-28a7-4f96-99a5-68b03b91abc5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 49a76b7d-8b6d-4190-b2cf-01ecc1668278. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:18.528504 [ 35674 ] {f1a14bd5-e742-410a-9bad-1a8950e146fe} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34790) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae841 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8ac2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:26:18.531479 [ 35674 ] {f1a14bd5-e742-410a-9bad-1a8950e146fe} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toWeek('invalid'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae841 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8ac2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:26:18.711011 [ 35673 ] {208f9495-0742-40d9-8595-92cd28d3111e} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime(val, tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE snowflakeToDateTime(val, tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0c1f2e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:18.714781 [ 35673 ] {208f9495-0742-40d9-8595-92cd28d3111e} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime(val, tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0c1f2e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:19.381999 [ 35674 ] {4b19298b-6016-4f16-bddd-1978a7c43997} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toYearWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34790) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toYearWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7d81 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2d82 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:26:19.384563 [ 35674 ] {4b19298b-6016-4f16-bddd-1978a7c43997} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toYearWeek('invalid'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7d81 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2d82 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 2025.06.18 11:26:19.589256 [ 1391 ] {a99eef79-250f-46c5-89dc-48350e956e1c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id e7c09b73-361b-4156-ad76-9eb057368c46. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:19.590907 [ 1391 ] {a99eef79-250f-46c5-89dc-48350e956e1c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id dd988bc3-1c1e-4b4d-afa7-f2f1a2038351. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:19.591597 [ 1391 ] {a99eef79-250f-46c5-89dc-48350e956e1c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1d7fa8cf-8de0-4390-9301-846688571d7d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:19.677838 [ 35673 ] {7a481f9f-c537-420e-9bb7-1e7667333389} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime64(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: SELECT val FROM tab WHERE snowflakeToDateTime64(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0c4209 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:19.681413 [ 35673 ] {7a481f9f-c537-420e-9bb7-1e7667333389} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime64(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c0c4209 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342addc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:26:21.101888 [ 1395 ] {df70db3c-efe6-4d37-a635-7379a8f25c3c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id f18f2705-6ffa-48b7-98dd-5cef1cd7fee8. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:21.102750 [ 1395 ] {df70db3c-efe6-4d37-a635-7379a8f25c3c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 8743f3eb-5023-4933-8460-34afef6c5087. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:21.103930 [ 1395 ] {df70db3c-efe6-4d37-a635-7379a8f25c3c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1116bac2-826e-45de-bf0d-87500e6a999e. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:21.104722 [ 1395 ] {df70db3c-efe6-4d37-a635-7379a8f25c3c} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 8201dd51-f7fa-422c-99f7-d71a9f4b788f. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:21.510832 [ 35674 ] {f4a1928b-ceb8-4b1c-a11f-04d4704df41e} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toDayOfWeek(__table1.invalid :: 1) -> toDayOfWeek(__table1.invalid) UInt8 : 0'. (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34790) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toDayOfWeek(invalid) FROM `tab`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e3007 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcd22 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:21.518231 [ 35674 ] {f4a1928b-ceb8-4b1c-a11f-04d4704df41e} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toDayOfWeek(__table1.invalid :: 1) -> toDayOfWeek(__table1.invalid) UInt8 : 0'. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e3007 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcd22 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:22.076794 [ 35673 ] {d2eddfe4-0b93-4011-8fdf-d1b940dbf0ce} executeQuery: Code: 44. DB::Exception: Illegal column timezone of time zone argument of function, must be a constant string: While processing _CAST(toTimezone(date, timezone) AS viewer_date_tmp_alter7930709884943666653, 'DateTime') AS viewer_date: default expression and column type are incompatible. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46790) (comment: 00515_enhanced_time_zones.sql) (in query: CREATE TABLE tab (`country` LowCardinality(FixedString(7)) DEFAULT 'unknown', `city` LowCardinality(String) DEFAULT 'unknown', `region` LowCardinality(String) DEFAULT 'unknown', `continent` LowCardinality(FixedString(7)) DEFAULT 'unknown', `is_eu_country` Bool, `date` DateTime CODEC(DoubleDelta, LZ4), `viewer_date` DateTime ALIAS toTimezone(date, timezone), `device_browser` LowCardinality(String) DEFAULT 'unknown', `metro_code` LowCardinality(String) DEFAULT 'unknown', `domain` String DEFAULT 'unknown', `device_platform` LowCardinality(String) DEFAULT 'unknown', `device_type` LowCardinality(String) DEFAULT 'unknown', `device_vendor` LowCardinality(String) DEFAULT 'unknown', `ip` FixedString(39) DEFAULT 'unknown', `lat` Decimal(8, 6) CODEC(T64), `lng` Decimal(9, 6) CODEC(T64), `asset_id` String DEFAULT 'unknown', `is_personalized` Bool, `metric` String, `origin` String DEFAULT 'unknown', `product_id` UInt64 CODEC(T64), `referer` String DEFAULT 'unknown', `server_side` Int8 CODEC(T64), `third_party_id` String DEFAULT 'unknown', `partner_slug` LowCardinality(FixedString(10)) DEFAULT 'unknown', `user_agent` String DEFAULT 'unknown', `user_id` UUID, `zip` FixedString(10) DEFAULT 'unknown', `timezone` LowCardinality(String), `as_organization` LowCardinality(String) DEFAULT 'unknown', `content_cat` Array(String), `playback_method` LowCardinality(String) DEFAULT 'unknown', `store_id` LowCardinality(String) DEFAULT 'unknown', `store_url` String DEFAULT 'unknown', `timestamp` Nullable(DateTime), `ad_count` Int8 CODEC(T64), `ad_type` LowCardinality(FixedString(10)) DEFAULT 'unknown', `ad_categories` Array(FixedString(8)), `blocked_ad_categories` Array(FixedString(8)), `break_max_ad_length` Int8 CODEC(T64), `break_max_ads` Int8 CODEC(T64), `break_max_duration` Int8 CODEC(T64), `break_min_ad_length` Int8 CODEC(T64), `break_position` LowCardinality(FixedString(18)) DEFAULT 'unknown', `media_playhead` String DEFAULT 'unknown', `placement_type` Int8 CODEC(T64), `transaction_id` String, `universal_ad_id` Array(String), `client_ua` LowCardinality(String) DEFAULT 'unknown', `device_ip` FixedString(39) DEFAULT 'unknown', `device_ua` LowCardinality(String) DEFAULT 'unknown', `ifa` String, `ifa_type` LowCardinality(String) DEFAULT 'unknown', `vast_lat` Decimal(8, 6) CODEC(T64), `vast_long` Decimal(9, 6) CODEC(T64), `server_ua` String DEFAULT 'unknown', `app_bundle` String DEFAULT 'unknown', `page_url` String DEFAULT 'unknown', `api_framework` Array(UInt8), `click_type` LowCardinality(String), `extensions` Array(String), `media_mime` Array(String), `om_id_partner` LowCardinality(String) DEFAULT 'unknown', `player_capabilities` Array(FixedString(12)), `vast_versions` Array(UInt8), `verification_vendors` Array(String), `ad_play_head` String DEFAULT 'unknown', `ad_serving_id` String DEFAULT 'unknown', `asset_uri` String DEFAULT 'unknown', `content_id` String DEFAULT 'unknown', `content_uri` String DEFAULT 'unknown', `inventory_state` Array(FixedString(14)), `player_size` Array(UInt8), `player_state` Array(FixedString(12)), `pod_sequence` Int8 CODEC(T64), `click_position` Array(UInt32), `error_code` Int16 CODEC(T64), `error_reason` Int8 CODEC(T64), `gdpr_consent` String DEFAULT 'unknown', `limited_tracking` Bool, `regulations` String DEFAULT 'unknown', `content_category` Array(String), PROJECTION projection_TPAG_VAST_date (SELECT * ORDER BY toYYYYMMDD(date), metric, product_id, asset_id)) ENGINE = MergeTree ORDER BY (product_id, metric, asset_id, toYYYYMMDD(date)) SETTINGS index_granularity = 64099, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 419547607, compact_parts_max_bytes_to_buffer = 17105710, compact_parts_max_granules_to_buffer = 165, compact_parts_merge_max_bytes_to_prefetch_part = 15105757, merge_max_block_size = 7135, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 28004624, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 59223, primary_key_compress_block_size = 35200), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::ToTimeZoneOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c762442 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033217fd1 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b12fab 16. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 17. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 18. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 20. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 23. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 24. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:26:22.084716 [ 35673 ] {d2eddfe4-0b93-4011-8fdf-d1b940dbf0ce} TCPHandler: Code: 44. DB::Exception: Illegal column timezone of time zone argument of function, must be a constant string: While processing _CAST(toTimezone(date, timezone) AS viewer_date_tmp_alter7930709884943666653, 'DateTime') AS viewer_date: default expression and column type are incompatible. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9557f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f955cb1 6. DB::(anonymous namespace)::ToTimeZoneOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c762442 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033217fd1 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b09e8d 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b2ecd3 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b119c8 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b12fab 16. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0ba75 17. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033ae87f5 18. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a676bf 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9b453 20. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9c0f2 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ec131 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034899698 23. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a0707 24. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:26:22.394180 [ 35674 ] {fdedbf50-198e-4334-baba-04ddaa47f6d6} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toWeek(__table1.invalid :: 1) -> toWeek(__table1.invalid) UInt8 : 0'. (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34790) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toWeek(invalid) FROM `tab`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae841 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8ac2 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:22.403622 [ 35674 ] {fdedbf50-198e-4334-baba-04ddaa47f6d6} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toWeek(__table1.invalid :: 1) -> toWeek(__table1.invalid) UInt8 : 0'. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae841 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8ac2 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:23.298873 [ 35674 ] {37b5183c-470d-4ddd-bdcf-783bb5532bff} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toYearWeek(__table1.invalid :: 1) -> toYearWeek(__table1.invalid) UInt32 : 0'. (CANNOT_PARSE_DATETIME) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34790) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toYearWeek(invalid) FROM `tab`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7d81 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2d82 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:23.310025 [ 35674 ] {37b5183c-470d-4ddd-bdcf-783bb5532bff} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toYearWeek(__table1.invalid :: 1) -> toYearWeek(__table1.invalid) UInt32 : 0'. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000202706b4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020243044 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7d81 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2d82 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:25.734071 [ 1402 ] {2753b426-2935-4d04-a9cf-88e62f2a5d80} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 3d52e85f-3bbe-40b9-8aa3-a8ab0b512bca. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:27.394802 [ 1391 ] {5aa56aed-250f-4ead-9f39-841debe5f821} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id e0fd36de-d040-46cc-80de-4100b16dc03a. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:27.396269 [ 1391 ] {5aa56aed-250f-4ead-9f39-841debe5f821} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id fc08ad4a-4828-4d59-a22d-5aa27d8d11e1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:27.396950 [ 1391 ] {5aa56aed-250f-4ead-9f39-841debe5f821} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id ac5c4b9d-4c24-4cf0-9afb-b56e27303e78. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:27.398372 [ 1391 ] {5aa56aed-250f-4ead-9f39-841debe5f821} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 77c02aaa-159d-4192-be8d-48dbe27d4e4a. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:27.400364 [ 1391 ] {5aa56aed-250f-4ead-9f39-841debe5f821} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 2fcecbcc-1bfe-4006-b69a-368fed12f6de. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:27.401049 [ 1391 ] {5aa56aed-250f-4ead-9f39-841debe5f821} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 61308b77-ea7b-4e5f-9f7f-8bec3473a623. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:27.401692 [ 1391 ] {5aa56aed-250f-4ead-9f39-841debe5f821} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 92e2956d-f528-45a9-817c-1aa952544ed6. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:28.992278 [ 1402 ] {b5c18ecd-1cb8-41b9-8285-67e3f9715757} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 3e93bd80-b894-452e-9586-d080355adeba. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:30.538938 [ 1391 ] {93e6d4f0-e283-4990-a712-d1a669667fef} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 2b3e09bf-77c4-4f8a-83cd-ce325699c5ed. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:30.540323 [ 1391 ] {93e6d4f0-e283-4990-a712-d1a669667fef} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 7c9b2260-959b-4bfa-a7b3-d1a04f608c21. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:30.541788 [ 1391 ] {93e6d4f0-e283-4990-a712-d1a669667fef} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 308b7b79-be5f-44db-b0aa-482e21b74a9e. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:32.212566 [ 1395 ] {24fdf56e-3612-4438-8391-f133618e1ff3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id bc7aaaac-8b8b-4734-b5cb-cb00bca93049. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:32.213742 [ 1395 ] {24fdf56e-3612-4438-8391-f133618e1ff3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id ddf1455a-e023-46fa-bf6d-cf20c91b7100. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:32.221911 [ 1395 ] {24fdf56e-3612-4438-8391-f133618e1ff3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id d0300e15-12d8-4661-91aa-f091e96dc3a9. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:32.222590 [ 1395 ] {24fdf56e-3612-4438-8391-f133618e1ff3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 83562987-6a74-4715-8d37-4002ac78b675. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:33.745090 [ 1402 ] {6e2ab7f7-62f1-446b-8af2-419186131afa} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 7009a2f2-6693-4a68-a064-8086db8ae770. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:35.313373 [ 1395 ] {2a5ea723-4257-4518-a106-b83a3871063f} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 34a21bed-d0e1-4fa8-b670-bf78d6d60fa3. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:36.857938 [ 1402 ] {1a8e27b2-b4df-47a8-8cd8-3fbcb33b94c1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 5adb5fb7-ef61-40c4-bee5-a9458e0663a4. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:38.205407 [ 58693 ] {125773d7-ac47-417f-8b8c-dcf4ae6f437f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46472) (comment: 00809_add_days_segfault.sql) (in query: SELECT quantileDeterministic([], identity(( SELECT subtractDays((CAST((566450.398706) AS DateTime)), 54) ) )), '\0', [];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantileDeterministic.cpp:138: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b876a2c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d8df0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:38.208899 [ 58693 ] {125773d7-ac47-417f-8b8c-dcf4ae6f437f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a85220d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantileDeterministic.cpp:138: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002b876a2c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d8df0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:38.436376 [ 1391 ] {23d2f273-b714-4a0b-a0ea-883594dc87c8} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id d3aa91d4-8891-4a70-b9c1-3a99be6a4eb5. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:38.439120 [ 1391 ] {23d2f273-b714-4a0b-a0ea-883594dc87c8} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id f98cbe4a-56f3-4bcf-aa8b-ee5a6a2b5c44. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:39.295597 [ 58693 ] {bc18a303-b615-4af3-96b6-3c581abc290a} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope (SELECT [], '(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000001c8e2f31 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c7cd1a6 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. DB::(anonymous namespace)::FunctionCaseWithExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dc5c7c3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 29. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 2025.06.18 11:26:39.300544 [ 58693 ] {bc18a303-b615-4af3-96b6-3c581abc290a} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope (SELECT [], '(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000001c8e2f31 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c7cd1a6 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. DB::(anonymous namespace)::FunctionCaseWithExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dc5c7c3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334422ad 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 29. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 2025.06.18 11:26:39.999841 [ 1395 ] {0c70dfe8-10fc-4cb9-830a-163939cbfc6e} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id a56972de-b4dd-40e2-9a8f-c21bc5bff22d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:40.002146 [ 1395 ] {0c70dfe8-10fc-4cb9-830a-163939cbfc6e} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id a6ab2922-465d-4ce9-a007-93737a0834a1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:40.759001 [ 59082 ] {82b25d04-fa34-4681-b483-5f7dad321f35} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46626) (comment: 01122_totals_rollup_having_block_header.sql) (in query: SELECT a, b, count(*) FROM rollup_having GROUP BY a, b WITH ROLLUP WITH TOTALS HAVING a IS NOT NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:40.762383 [ 59082 ] {82b25d04-fa34-4681-b483-5f7dad321f35} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:40.814915 [ 59082 ] {80c65ce3-6250-4d21-8a09-cae135b9b42d} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46626) (comment: 01122_totals_rollup_having_block_header.sql) (in query: SELECT a, b, count(*) FROM rollup_having GROUP BY a, b WITH ROLLUP WITH TOTALS HAVING a IS NOT NULL and b IS NOT NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:40.818449 [ 59082 ] {80c65ce3-6250-4d21-8a09-cae135b9b42d} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5293: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000334310df 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:41.628741 [ 1391 ] {c3c6c4d7-837c-4eee-964d-cb8a56646d90} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 52792775-9e32-4026-8684-10ab32f42e3c. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:41.629557 [ 1391 ] {c3c6c4d7-837c-4eee-964d-cb8a56646d90} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 03c31eba-cc20-4059-9ed4-9ed84d494870. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:41.631154 [ 1391 ] {c3c6c4d7-837c-4eee-964d-cb8a56646d90} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 32f01f20-40c7-4ebb-802a-d68bc914fa8d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:41.631639 [ 1391 ] {c3c6c4d7-837c-4eee-964d-cb8a56646d90} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 557036e9-d571-40e1-ab4b-6b19f55dc7f2. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:41.632286 [ 1391 ] {c3c6c4d7-837c-4eee-964d-cb8a56646d90} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 17fea4aa-bd44-4511-91d5-4170b9d00823. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:41.632969 [ 1391 ] {c3c6c4d7-837c-4eee-964d-cb8a56646d90} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id beadd3d2-3003-4670-bc41-d377282c28fa. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:43.253610 [ 1395 ] {806ab2d7-d287-407d-8d31-39adb972984b} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id d4ecf240-4172-4593-a378-e9cf4a3aec14. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:44.813192 [ 1402 ] {82b31b34-fb78-4fca-a475-55b46ae8adcd} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 92678a8f-1a69-463d-bb98-c307b410c9b8. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:44.814770 [ 1402 ] {82b31b34-fb78-4fca-a475-55b46ae8adcd} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 8942905d-3964-40bb-b3fa-18d173148168. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:44.816269 [ 1402 ] {82b31b34-fb78-4fca-a475-55b46ae8adcd} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 2ba97003-35dd-450f-bfa5-a4df12da73b5. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:46.391788 [ 1395 ] {a1dc50a4-cc74-4144-b2a4-431433bdd351} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1b64469a-5ebd-4cdc-b8df-136bb215152b. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:47.932706 [ 1402 ] {8c4958e0-2987-4082-b106-434d5a37e116} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 797c9d51-8f4e-4887-9224-fd5ce3fec70a. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:47.935005 [ 1402 ] {8c4958e0-2987-4082-b106-434d5a37e116} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 5ccad647-7590-43fd-88a5-128c1c3a4798. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:49.180164 [ 35669 ] {441f38ab-e1de-495d-8026-2f26405d3f0d} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34266) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: ALTER TABLE replicated_table_for_alter1 MODIFY SETTING index_granularity = 4096;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3567: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756605 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:49.184109 [ 35669 ] {441f38ab-e1de-495d-8026-2f26405d3f0d} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3567: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756605 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:49.658085 [ 1391 ] {8e00856a-0f4f-4388-a4b2-a7f333421cc0} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 8edd64a8-de75-440a-81da-f9558d3f7e7c. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:49.659251 [ 1391 ] {8e00856a-0f4f-4388-a4b2-a7f333421cc0} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 0e15cdd8-ebe4-4b02-9de4-81791952b297. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:49.660802 [ 1391 ] {8e00856a-0f4f-4388-a4b2-a7f333421cc0} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 0b10195f-ce41-49c6-b099-5f3a55c2c87d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:50.760753 [ 59101 ] {0cc6307f-a327-40a1-91b7-6aaf6cddb0be} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34292) (comment: 00800_low_cardinality_merge_join.gen.sql) (in query: SELECT * FROM (SELECT dummy AS val FROM system.one) s1 ANY LEFT JOIN (SELECT dummy AS val FROM system.one) s2 ON val + 0 = val * 1 ORDER BY val;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:50.765463 [ 59101 ] {0cc6307f-a327-40a1-91b7-6aaf6cddb0be} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:50.967651 [ 58693 ] {f6a0609b-c42f-4b6e-9bb4-f7a314d59d69} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34324) (comment: 01784_parallel_formatting_memory.sql) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. ./src/Common/PODArray.h:0: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036ffd008 9. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036fc9d75 10. ./build_docker/./src/Columns/ColumnConst.cpp:0: DB::ColumnConst::convertToFullColumn() const @ 0x00000000370d3384 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000370d7b2e 12. ./build_docker/./src/Formats/NativeWriter.cpp:0: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7bcae 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 14. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:50.973221 [ 58693 ] {f6a0609b-c42f-4b6e-9bb4-f7a314d59d69} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff75e05 8. ./src/Common/PODArray.h:0: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036ffd008 9. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000036fc9d75 10. ./build_docker/./src/Columns/ColumnConst.cpp:0: DB::ColumnConst::convertToFullColumn() const @ 0x00000000370d3384 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000370d7b2e 12. ./build_docker/./src/Formats/NativeWriter.cpp:0: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ad7bcae 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abd9975 14. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1215 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:51.178968 [ 1395 ] {95e072d6-8cbd-47df-8aa7-729608695bd1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id afd8646a-62be-4606-be72-1fab614b9a5d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:51.179903 [ 1395 ] {95e072d6-8cbd-47df-8aa7-729608695bd1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 9cbf0a83-1588-4d85-a1f4-f4908461fa12. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:51.995514 [ 35669 ] {f1d4c49a-acaa-421b-a569-74daa32f0f46} executeQuery: Code: 252. DB::Exception: Too many parts (2 with average size of 327.00 B) in table 'test_7n81bl3d.replicated_table_for_alter2 (a4d9218b-cabb-498b-b855-5bf7dba3d7c3)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34266) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: INSERT INTO replicated_table_for_alter2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:52.004733 [ 35669 ] {f1d4c49a-acaa-421b-a569-74daa32f0f46} TCPHandler: Code: 252. DB::Exception: Too many parts (2 with average size of 327.00 B) in table 'test_7n81bl3d.replicated_table_for_alter2 (a4d9218b-cabb-498b-b855-5bf7dba3d7c3)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:52.775384 [ 1391 ] {a6777cb4-b73a-41df-869c-2af7b429764b} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 78dc4ef8-d224-4a54-86c9-dc50cf5ecced. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:54.307871 [ 1395 ] {fd51c9f6-a58f-4a28-b331-ac4e43f54532} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1bc5bfd6-1ae7-4340-b9ef-dd1868001e9b. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:54.309181 [ 1395 ] {fd51c9f6-a58f-4a28-b331-ac4e43f54532} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 5800e88e-2f29-45e4-96db-cf46ec4a4d23. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:54.309708 [ 1395 ] {fd51c9f6-a58f-4a28-b331-ac4e43f54532} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id a426a80b-e80a-45c7-9178-cac58707b649. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:54.310373 [ 1395 ] {fd51c9f6-a58f-4a28-b331-ac4e43f54532} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 2538f4b5-dc4f-4a61-ba90-d1d47a07a4b4. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:54.311165 [ 1395 ] {fd51c9f6-a58f-4a28-b331-ac4e43f54532} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id d50c7158-defe-4a55-8f70-8e29fb99e239. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:54.311662 [ 1395 ] {fd51c9f6-a58f-4a28-b331-ac4e43f54532} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id e8bfaa96-fe4d-408c-b330-10ee1b95469d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:54.679382 [ 35669 ] {5778c976-0861-4b16-b778-394be5d6753e} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34266) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: ALTER TABLE replicated_table_for_reset_setting1 MODIFY SETTING index_granularity = 4096;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3567: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756605 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:54.682124 [ 35669 ] {5778c976-0861-4b16-b778-394be5d6753e} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3567: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756605 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:55.867936 [ 1402 ] {e5c16ff0-16e5-4172-b04a-385fa9104296} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 417f71d8-703a-44c4-936f-4a8e27348f60. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:55.868861 [ 1402 ] {e5c16ff0-16e5-4172-b04a-385fa9104296} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 1aca5589-63e8-4a53-9dac-4196d1f773b1. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:55.869664 [ 1402 ] {e5c16ff0-16e5-4172-b04a-385fa9104296} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id e6763ec8-8b24-421c-8a92-e9fcd905a782. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:55.870456 [ 1402 ] {e5c16ff0-16e5-4172-b04a-385fa9104296} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 81faa2c5-ad12-4d9c-8280-13d7c1c5490b. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:55.871042 [ 1402 ] {e5c16ff0-16e5-4172-b04a-385fa9104296} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id c64fc138-2a23-4be6-a2c0-d00e622e53d2. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:55.871832 [ 1402 ] {e5c16ff0-16e5-4172-b04a-385fa9104296} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 583019a2-25ba-4ecc-a9d2-d14a6376ac3f. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:55.961042 [ 59101 ] {3015237c-cab0-403f-9cc3-5b2c929a725e} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34292) (comment: 00800_low_cardinality_merge_join.gen.sql) (in query: SELECT * FROM (SELECT dummy AS val FROM system.one) s1 ANY LEFT JOIN (SELECT dummy AS val FROM system.one) s2 ON val + 0 = val * 1 ORDER BY val;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:55.965945 [ 59101 ] {3015237c-cab0-403f-9cc3-5b2c929a725e} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:56.108771 [ 35669 ] {72b0d4b6-65c8-4aa9-a213-829595cb1be4} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'unknown_setting' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34266) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: -- don't execute alter with incorrect setting ALTER TABLE replicated_table_for_reset_setting1 RESET SETTING check_delay_period, unknown_setting;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756236 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:56.112201 [ 35669 ] {72b0d4b6-65c8-4aa9-a213-829595cb1be4} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'unknown_setting' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756236 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:57.413086 [ 1395 ] {07db5f26-8bcc-46b7-b92b-92583bed34f1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 7eec01be-114e-49e2-b3b7-7a9abd79ad5d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:57.416438 [ 1395 ] {07db5f26-8bcc-46b7-b92b-92583bed34f1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 6b187c9d-3feb-4421-8572-bc015c87d926. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:57.417670 [ 1395 ] {07db5f26-8bcc-46b7-b92b-92583bed34f1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 2af60ed5-9156-4b3b-9423-8fcab88cd3cd. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:57.418760 [ 1395 ] {07db5f26-8bcc-46b7-b92b-92583bed34f1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 827c7edc-4fcd-474a-aaaa-5023f348f45a. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:58.476505 [ 51841 ] {47bbc2be-7d29-40cf-860e-fd3d228f842a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: --- aes_encrypt_mysql(string, key, block_mode[, init_vector, AAD]) -- The MySQL-compatitable encryption, only ecb, cbc and ofb modes are supported, -- just like for MySQL -- https://dev.mysql.com/doc/refman/8.0/en/encryption-functions.html#function_aes-encrypt -- https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_block_encryption_mode -- Please note that for keys that exceed mode-specific length, keys are folded in a MySQL-specific way, -- meaning that whole key is used, but effective key length is still determined by mode. -- when key doesn't exceed the default mode length, ecryption result equals with AES_encypt() ----------------------------------------------------------------------------------------- -- error cases ----------------------------------------------------------------------------------------- SELECT aes_encrypt_mysql();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:26:58.480046 [ 51841 ] {47bbc2be-7d29-40cf-860e-fd3d228f842a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:26:58.522791 [ 51841 ] {f6d61af1-73cf-45a0-8647-cee41281ecdd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:26:58.527019 [ 51841 ] {f6d61af1-73cf-45a0-8647-cee41281ecdd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:26:58.574561 [ 51841 ] {f5d16f4d-7ae1-45d9-a7ba-031a1c06ab36} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:26:58.637983 [ 51841 ] {f5d16f4d-7ae1-45d9-a7ba-031a1c06ab36} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:26:59.006878 [ 1402 ] {b8159017-d4b9-4806-b1e9-6018199a2efd} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 129e8d82-a97e-494d-b011-86a10aefd37a. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:59.009447 [ 1402 ] {b8159017-d4b9-4806-b1e9-6018199a2efd} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 2deff9a6-a40c-4051-86cb-36d3634dd4fa. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:26:59.489359 [ 51841 ] {a435e906-b497-4cb3-94c0-a25d120b69f4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: UInt16: In scope SELECT aes_encrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:59.492796 [ 51841 ] {a435e906-b497-4cb3-94c0-a25d120b69f4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: UInt16: In scope SELECT aes_encrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:26:59.558597 [ 59020 ] {eed9ee06-267d-4ac0-a6a5-7bb5af5bcf2d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41652) (comment: 00002_system_numbers.sql) (in query: select x from system.numbers limit 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:59.561912 [ 59020 ] {eed9ee06-267d-4ac0-a6a5-7bb5af5bcf2d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:59.614308 [ 59020 ] {cc6106a8-15fc-43e5-82fc-8862e1accca3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, number FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41652) (comment: 00002_system_numbers.sql) (in query: SELECT x, number FROM system.numbers LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:26:59.617799 [ 59020 ] {cc6106a8-15fc-43e5-82fc-8862e1accca3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, number FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.172349 [ 59020 ] {521aaf33-4c10-4371-9940-33d3d416662f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'system.number' in scope SELECT * FROM system.number LIMIT 1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41652) (comment: 00002_system_numbers.sql) (in query: SELECT * FROM system.number LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.175279 [ 59020 ] {521aaf33-4c10-4371-9940-33d3d416662f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'system.number' in scope SELECT * FROM system.number LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.209035 [ 59020 ] {d8cdba34-f6a8-461d-8ed0-f7ec34749108} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'system' in scope SELECT * FROM system LIMIT 1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41652) (comment: 00002_system_numbers.sql) (in query: SELECT * FROM system LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.212219 [ 59020 ] {d8cdba34-f6a8-461d-8ed0-f7ec34749108} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'system' in scope SELECT * FROM system LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.241928 [ 59020 ] {27f24563-b110-48c3-aab9-2fb4903eee88} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT * FROM numbers LIMIT 1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41652) (comment: 00002_system_numbers.sql) (in query: SELECT * FROM numbers LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.245666 [ 59020 ] {27f24563-b110-48c3-aab9-2fb4903eee88} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT * FROM numbers LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.282868 [ 59020 ] {cd7ddae7-d546-4666-8ef0-70d1bd10d3b8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'sys.number' in scope SELECT sys.number FROM system.numbers AS sys_num LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41652) (comment: 00002_system_numbers.sql) (in query: SELECT sys.number FROM system.numbers AS sys_num LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.286170 [ 59020 ] {cd7ddae7-d546-4666-8ef0-70d1bd10d3b8} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'sys.number' in scope SELECT sys.number FROM system.numbers AS sys_num LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:00.333214 [ 51841 ] {31bc295e-c31e-4093-9258-223319249903} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98baed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:00.337805 [ 51841 ] {31bc295e-c31e-4093-9258-223319249903} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98baed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:00.384463 [ 51841 ] {45801981-6a88-4183-b281-28f319f365db} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98baed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:00.387874 [ 51841 ] {45801981-6a88-4183-b281-28f319f365db} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98baed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:00.599838 [ 1391 ] {f414da6d-98e4-4817-beba-f3de0f651f9d} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 252fab23-e624-429e-85c1-db8745b9a338. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:27:00.600830 [ 1391 ] {f414da6d-98e4-4817-beba-f3de0f651f9d} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id d206701b-bbdb-405a-9de1-21c86773372c. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:27:01.248272 [ 51841 ] {529ee9d8-309e-473a-9597-beb30ca2f030} executeQuery: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98be38 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:01.251992 [ 51841 ] {529ee9d8-309e-473a-9597-beb30ca2f030} TCPHandler: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98be38 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:01.377534 [ 59101 ] {b5f764f5-13e1-45e9-9d35-1f9534d74cbb} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34292) (comment: 00800_low_cardinality_merge_join.gen.sql) (in query: SELECT * FROM (SELECT dummy AS val FROM system.one) s1 ANY LEFT JOIN (SELECT dummy AS val FROM system.one) s2 ON val + 0 = val * 1 ORDER BY val;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:01.381558 [ 59101 ] {b5f764f5-13e1-45e9-9d35-1f9534d74cbb} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034dd2629 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034dc89f5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d7fdd2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d59c37 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:01.675261 [ 35659 ] {} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.06.18 11:27:01.691926 [ 35659 ] {3ad9f383-cc2d-4104-81f0-961633cd3e4d} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.06.18 11:27:01.696076 [ 35659 ] {3ad9f383-cc2d-4104-81f0-961633cd3e4d} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.06.18 11:27:01.771404 [ 35659 ] {6526c176-61e2-41d8-ab08-9f6882b29f1e} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.06.18 11:27:01.775202 [ 35659 ] {6526c176-61e2-41d8-ab08-9f6882b29f1e} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.06.18 11:27:01.842561 [ 35659 ] {29d74e1a-0e71-4d85-a2fa-080dd2d43eed} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.06.18 11:27:01.859920 [ 35659 ] {} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.06.18 11:27:02.042752 [ 1590 ] {c98b8e75-9de4-4c8e-8e56-fa7d072c284b} executeQuery: Code: 10. DB::Exception: Not found column x in block __table1.dummy UInt8 UInt8(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58194) (comment: 01527_bad_aggregation_in_lambda.sql) (in query: SELECT arrayMap(x -> x * sum(x), range(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000003325c54e 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d174d5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfee92 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:02.046314 [ 1590 ] {c98b8e75-9de4-4c8e-8e56-fa7d072c284b} TCPHandler: Code: 10. DB::Exception: Not found column x in block __table1.dummy UInt8 UInt8(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000003325c54e 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d174d5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfee92 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:02.119615 [ 51841 ] {a55cf6ff-56f2-4ecf-9d3e-12c3a8791678} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: UInt16: In scope SELECT encrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:02.123429 [ 51841 ] {a55cf6ff-56f2-4ecf-9d3e-12c3a8791678} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: UInt16: In scope SELECT encrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:02.246830 [ 1395 ] {df8127f4-5c25-4faf-91a2-ec03f79774a1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 96f22f69-8367-4f43-85ef-6f2c2bcf7e0d. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:27:02.247911 [ 1395 ] {df8127f4-5c25-4faf-91a2-ec03f79774a1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id 41e72ae8-382e-4136-bd7e-498200f785ca. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:27:02.248751 [ 1395 ] {df8127f4-5c25-4faf-91a2-ec03f79774a1} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_0nmtskj0.t_async_insert_dedup FORMAT Values' with query id dd47a7c3-cee7-47a9-bad7-8b3c255b5b9e. DB::Exception: Cannot parse input: expected '(' before: 'format JSONEachRow': at row 0 2025.06.18 11:27:02.950133 [ 51841 ] {ea6b89b7-f0f0-4fc4-a6c7-f24f9ac8e5a6} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT encrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf8a63 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:02.954194 [ 51841 ] {ea6b89b7-f0f0-4fc4-a6c7-f24f9ac8e5a6} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT encrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf8a63 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:02.988236 [ 51841 ] {66886393-28aa-4383-a549-3c94959fe81a} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT encrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf8a63 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:02.990945 [ 51841 ] {66886393-28aa-4383-a549-3c94959fe81a} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT encrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf8a63 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:03.025152 [ 51841 ] {775e6eda-fb00-4b6a-b4be-aad44b5e36f4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_encrypt_mysql'. Expected: encryption key binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:03.028085 [ 51841 ] {775e6eda-fb00-4b6a-b4be-aad44b5e36f4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_encrypt_mysql'. Expected: encryption key binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:03.849641 [ 51841 ] {c48e0ce4-a41b-4fa8-9a3d-2b0b16521fe3} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b98ddec 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98ac5b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:03.852653 [ 51841 ] {c48e0ce4-a41b-4fa8-9a3d-2b0b16521fe3} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b98ddec 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98ac5b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:04.645040 [ 51841 ] {e2f4415c-bb7d-4f35-a1ef-1a6d54a4c0fa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:27:04.647601 [ 51841 ] {e2f4415c-bb7d-4f35-a1ef-1a6d54a4c0fa} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:27:04.680605 [ 51841 ] {10c66e3a-42de-4011-abcd-fc348fb47c29} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'encrypt'. Expected: encryption key binary string, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:04.683491 [ 51841 ] {10c66e3a-42de-4011-abcd-fc348fb47c29} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'encrypt'. Expected: encryption key binary string, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fafba 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:05.469521 [ 59009 ] {f8870b5c-0635-43ff-b7e5-c356e82003d0} Context: Server has databases (for example `ordinary_test_f8guun4a`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.06.18 11:27:05.532975 [ 51841 ] {f898e162-5a45-42f2-bbfd-364f8410a303} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafc553 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7bd9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:05.536014 [ 51841 ] {f898e162-5a45-42f2-bbfd-364f8410a303} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafc553 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7bd9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:05.569538 [ 51841 ] {f945390e-d503-4864-a2fb-c242786a2d21} executeQuery: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafc553 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7bd9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:05.572394 [ 51841 ] {f945390e-d503-4864-a2fb-c242786a2d21} TCPHandler: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafc553 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7bd9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:06.392252 [ 51841 ] {e6c4ecbd-1aa0-463e-97fc-6503462459c5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_encrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:06.395220 [ 51841 ] {e6c4ecbd-1aa0-463e-97fc-6503462459c5} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_encrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:06.928735 [ 35636 ] {1abd2ace-9bf5-43b2-8a6c-06ade1588775} executeQuery: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58280) (comment: 01504_rocksdb.sql) (in query: CREATE TABLE 01504_test (key String, value UInt32) Engine=EmbeddedRocksDB;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:700: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c52591 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:06.932585 [ 35636 ] {1abd2ace-9bf5-43b2-8a6c-06ade1588775} TCPHandler: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:700: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c52591 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:07.265216 [ 51841 ] {60e02d0c-73b0-44fc-929a-0ea196f053be} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b98ddec 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98afbe 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:07.268896 [ 51841 ] {60e02d0c-73b0-44fc-929a-0ea196f053be} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98836d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b98ddec 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b98afbe 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:07.530439 [ 35636 ] {db744d5f-df4c-4926-80d2-fb9671f604f5} executeQuery: Code: 47. DB::Exception: Missing columns: 'key2' while processing query: 'key2', required columns: 'key2' 'key2'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58280) (comment: 01504_rocksdb.sql) (in query: CREATE TABLE 01504_test (key String, value UInt32) Engine=EmbeddedRocksDB PRIMARY KEY(key2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038196ba7 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038199409 7. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:702: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c50e96 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:07.533610 [ 35636 ] {db744d5f-df4c-4926-80d2-fb9671f604f5} TCPHandler: Code: 47. DB::Exception: Missing columns: 'key2' while processing query: 'key2', required columns: 'key2' 'key2'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000003561efff 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000356411dd 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038196ba7 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000038199409 7. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:702: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c50e96 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:07.725183 [ 35675 ] {1ec7bed2-d4ea-449c-95da-69a519e84dd2} executeQuery: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58244) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3170: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759bd8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:07.728231 [ 35675 ] {1ec7bed2-d4ea-449c-95da-69a519e84dd2} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3170: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039759bd8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:07.919670 [ 58993 ] {5d4feb71-27e0-4600-9575-b92fb8215deb} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE data_read; to attach existing table or CREATE TABLE data_read ; to create new table or ATTACH TABLE data_read FROM '/path/to/data/'
; to create new table and attach data. 2025.06.18 11:27:08.067304 [ 35636 ] {ee091b94-fe43-42b3-8532-c6cf9615aea6} executeQuery: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58280) (comment: 01504_rocksdb.sql) (in query: CREATE TABLE 01504_test (key String, value UInt32) Engine=EmbeddedRocksDB PRIMARY KEY(key, value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:706: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c52700 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.070826 [ 35636 ] {ee091b94-fe43-42b3-8532-c6cf9615aea6} TCPHandler: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:706: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000030c52700 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7763a 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.115990 [ 51841 ] {31e38548-d315-4615-ba27-e57ac9e85592} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'encrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:08.119358 [ 51841 ] {31e38548-d315-4615-ba27-e57ac9e85592} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'encrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:08.242320 [ 35675 ] {ae409762-b474-4f82-b6c2-c100cb8daef3} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58244) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Int64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.245981 [ 35675 ] {ae409762-b474-4f82-b6c2-c100cb8daef3} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.747960 [ 35675 ] {0af3b644-23bf-4782-bbec-abf83a915c43} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58244) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version UInt16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3195: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a7ea 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.752104 [ 35675 ] {0af3b644-23bf-4782-bbec-abf83a915c43} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3195: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a7ea 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.815768 [ 35675 ] {a0ea2b66-7b88-408f-bb6a-20bfc3b76cfc} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58244) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Float64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.819049 [ 35675 ] {a0ea2b66-7b88-408f-bb6a-20bfc3b76cfc} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.887529 [ 35675 ] {4b29c4b6-2131-4a96-ba9e-4f5532fff4e2} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58244) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.891282 [ 35675 ] {4b29c4b6-2131-4a96-ba9e-4f5532fff4e2} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.946539 [ 35675 ] {436d928f-777a-4be3-a913-7e09c7194825} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58244) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.949239 [ 35675 ] {436d928f-777a-4be3-a913-7e09c7194825} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861b137 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3186: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975a6cd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348575d5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:08.995280 [ 51841 ] {85a7ab76-11f1-439d-a2a1-d2dd1b95fed6} executeQuery: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafcbe6 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7f13 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:09.035907 [ 51841 ] {85a7ab76-11f1-439d-a2a1-d2dd1b95fed6} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafcbe6 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7f13 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:09.076736 [ 51841 ] {c4996602-4fdf-4bf9-b261-970f39852f28} executeQuery: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafcbe6 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7f13 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:09.079444 [ 51841 ] {c4996602-4fdf-4bf9-b261-970f39852f28} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b988d8d 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000eafcbe6 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eaf7f13 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 2025.06.18 11:27:09.114244 [ 51841 ] {50de4ba3-e795-4e0d-b5ff-8a2657e31735} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:27:09.117486 [ 51841 ] {50de4ba3-e795-4e0d-b5ff-8a2657e31735} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008401a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbcc9 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b98c903 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:27:09.160542 [ 51841 ] {bc31553f-4970-4925-b334-9f2c85cc7b4d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:09.164705 [ 51841 ] {bc31553f-4970-4925-b334-9f2c85cc7b4d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:09.205456 [ 51841 ] {b585947a-780c-4ba6-9533-2f9c2d0ce34b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41632) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:09.208433 [ 51841 ] {b585947a-780c-4ba6-9533-2f9c2d0ce34b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084036a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fc8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fb035 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eaf9cab 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:09.215696 [ 817 ] {} ordinary_test_f8guun4a.data_read (ReplicatedMergeTreeAttachThread): No metadata in ZooKeeper for /tables/ordinary_test_f8guun4a/data/replicas/read: table will stay in readonly mode 2025.06.18 11:27:10.020086 [ 58993 ] {354f68af-c9ab-4b7e-8414-5952cb487911} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58318) (comment: 02980_s3_plain_DROP_TABLE_ReplicatedMergeTree.sh) (in query: insert into data_read values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5648: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000388f7795 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba171c 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba7649 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:10.024415 [ 58993 ] {354f68af-c9ab-4b7e-8414-5952cb487911} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5648: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000388f7795 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba171c 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba7649 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:10.547880 [ 58993 ] {f1083bda-9db2-4f3f-bf47-efb25f02188f} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_f8guun4a/data/replicas/read). (TABLE_IS_READ_ONLY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58318) (comment: 02980_s3_plain_DROP_TABLE_ReplicatedMergeTree.sh) (in query: optimize table data_read final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386d0472 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000388fc238 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:10.550660 [ 58993 ] {f1083bda-9db2-4f3f-bf47-efb25f02188f} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_f8guun4a/data/replicas/read). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386d0472 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000388fc238 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:11.186757 [ 58993 ] {5eafb905-7a65-4b33-ad1c-1412915292e7} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_f8guun4a/data/replicas/read). (TABLE_IS_READ_ONLY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58318) (comment: 02980_s3_plain_DROP_TABLE_ReplicatedMergeTree.sh) (in query: system sync replica data_read;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386d0472 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8813: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038a0c3dc 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000035976fe0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000003595538a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:11.190609 [ 58993 ] {5eafb905-7a65-4b33-ad1c-1412915292e7} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_f8guun4a/data/replicas/read). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386d0472 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8813: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038a0c3dc 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000035976fe0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000003595538a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:11.224172 [ 58693 ] {5f337d78-2f0c-49f3-b28a-a9a82a0b8d9c} executeQuery: Code: 1. DB::Exception: Set `store_polygon_key_column` setting in dictionary configuration to true to support reading from PolygonDictionary. (UNSUPPORTED_METHOD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58400) (comment: 02097_polygon_dictionary_store_key.sql) (in query: SELECT * FROM polygons_test_dictionary_no_option;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/PolygonDictionary.cpp:209: DB::IPolygonDictionary::read(std::vector> const&, unsigned long, unsigned long) const @ 0x00000000214c8677 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038245a8c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003815c411 7. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:11.227567 [ 58693 ] {5f337d78-2f0c-49f3-b28a-a9a82a0b8d9c} TCPHandler: Code: 1. DB::Exception: Set `store_polygon_key_column` setting in dictionary configuration to true to support reading from PolygonDictionary. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/PolygonDictionary.cpp:209: DB::IPolygonDictionary::read(std::vector> const&, unsigned long, unsigned long) const @ 0x00000000214c8677 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038245a8c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003815c411 7. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:14.120878 [ 35675 ] {1791cc77-802e-4c6c-a7e4-b3ec4fb40daa} executeQuery: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant CREATE TEMPORARY TABLE ON *.*. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37708) (comment: 02561_temporary_table_grants.sh) (in query: CREATE TEMPORARY TABLE table_memory_02561(name String)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d4cbf 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000312d4775 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d34ea 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312ed46c 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:14.128545 [ 35675 ] {1791cc77-802e-4c6c-a7e4-b3ec4fb40daa} TCPHandler: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant CREATE TEMPORARY TABLE ON *.*. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d4cbf 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000312d4775 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d34ea 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312ed46c 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:14.573440 [ 59061 ] {8d82199e-df03-4eb5-afb8-465c0238da8a} executeQuery: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37730) (comment: 01471_top_k_range_check.sql) (in query: SELECT length(topKWeighted(2, -9223372036854775808)(number, 1025)) FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:511: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ed89193 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:14.577426 [ 59061 ] {8d82199e-df03-4eb5-afb8-465c0238da8a} TCPHandler: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:511: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002ed89193 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b3ca3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dee81 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d95d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a1bae 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 2025.06.18 11:27:14.964538 [ 1585 ] {a95871a0-6560-4007-8de2-2bf594a97625} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37736) (comment: 02400_memory_accounting_on_error.sql) (in query: -- max_block_size to avoid randomization SELECT * FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536 SETTINGS max_memory_usage='1Gi', max_block_size=65505, log_queries=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff751c4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a7e10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383b4bf6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ba140 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383b1a13 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:14.969698 [ 1585 ] {a95871a0-6560-4007-8de2-2bf594a97625} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff751c4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a7e10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383b4bf6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ba140 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383b1a13 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:16.597855 [ 59098 ] {1ce90dd4-2aad-4f2b-865f-1a32d4c87689} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT BLAKE3(NULL, NULL, NULL);) 2025.06.18 11:27:16.602436 [ 59098 ] {1ce90dd4-2aad-4f2b-865f-1a32d4c87689} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:16.653040 [ 59098 ] {293cc10d-1fb8-4921-bf02-bce336d90856} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CHARACTER_LENGTH(NULL, NULL, NULL);) 2025.06.18 11:27:16.658149 [ 59098 ] {293cc10d-1fb8-4921-bf02-bce336d90856} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:16.697413 [ 59098 ] {16680610-8cfc-4145-b7e4-a60dae3320ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CHAR_LENGTH(NULL, NULL, NULL);) 2025.06.18 11:27:16.703019 [ 59098 ] {16680610-8cfc-4145-b7e4-a60dae3320ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:16.835909 [ 58693 ] {c9915c95-3ad8-4de6-8de8-692f458a1b89} executeQuery: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant CREATE ARBITRARY TEMPORARY TABLE ON *.*. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37824) (comment: 02561_temporary_table_grants.sh) (in query: CREATE TEMPORARY TABLE table_merge_tree_02561 (`name` String) ENGINE = MergeTree ORDER BY name SETTINGS index_granularity = 20880, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 31, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 268092441, compact_parts_max_granules_to_buffer = 163, compact_parts_merge_max_bytes_to_prefetch_part = 11736703, merge_max_block_size = 19381, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4641756513, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22076954, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 62216, primary_key_compress_block_size = 68648), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d4cbf 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000312d4775 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d34ea 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312ed46c 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:16.842091 [ 58693 ] {c9915c95-3ad8-4de6-8de8-692f458a1b89} TCPHandler: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant CREATE ARBITRARY TEMPORARY TABLE ON *.*. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d4cbf 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000312d4775 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d34ea 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312ed46c 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:16.934581 [ 59098 ] {a2869d61-241c-417f-a1e6-0f1fb80867c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC32(NULL, NULL, NULL);) 2025.06.18 11:27:16.939557 [ 59098 ] {a2869d61-241c-417f-a1e6-0f1fb80867c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:16.979445 [ 59098 ] {3a9b2302-751a-497d-9af0-1d3df6513898} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC32IEEE(NULL, NULL, NULL);) 2025.06.18 11:27:16.983978 [ 59098 ] {3a9b2302-751a-497d-9af0-1d3df6513898} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:17.029626 [ 59098 ] {a7525da2-068d-491b-9390-2a8c89dab73a} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC64(NULL, NULL, NULL);) 2025.06.18 11:27:17.034767 [ 59098 ] {a7525da2-068d-491b-9390-2a8c89dab73a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:17.077879 [ 59098 ] {1dfa1ba2-c637-4957-b08d-3c70cfa1f0e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT DATABASE(NULL, NULL, NULL);) 2025.06.18 11:27:17.083010 [ 59098 ] {1dfa1ba2-c637-4957-b08d-3c70cfa1f0e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:17.754034 [ 59098 ] {50e3c12b-0432-440b-8694-da7a9186cdc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FORMAT_BYTES(NULL, NULL, NULL);) 2025.06.18 11:27:17.762471 [ 59098 ] {50e3c12b-0432-440b-8694-da7a9186cdc7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:17.810101 [ 59098 ] {c1a4b6cd-cc60-432b-9205-220e67217376} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FQDN(NULL, NULL, NULL);) 2025.06.18 11:27:17.815896 [ 59098 ] {c1a4b6cd-cc60-432b-9205-220e67217376} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:17.864341 [ 59098 ] {0b8ec6a3-59a3-41d6-9687-28d99ae7dee8} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FROM_BASE64(NULL, NULL, NULL);) 2025.06.18 11:27:17.870677 [ 59098 ] {0b8ec6a3-59a3-41d6-9687-28d99ae7dee8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:17.919130 [ 59098 ] {c86dc8ed-0923-4824-992e-4f86f4137285} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FROM_DAYS(NULL, NULL, NULL);) 2025.06.18 11:27:17.925360 [ 59098 ] {c86dc8ed-0923-4824-992e-4f86f4137285} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.134296 [ 59098 ] {c4133934-7c20-44d8-90d0-8c4f4e5ce2cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET6_ATON(NULL, NULL, NULL);) 2025.06.18 11:27:18.139903 [ 59098 ] {c4133934-7c20-44d8-90d0-8c4f4e5ce2cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.197714 [ 59098 ] {3c5b0e82-269b-4c45-9423-eb0378d4701d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET6_NTOA(NULL, NULL, NULL);) 2025.06.18 11:27:18.206268 [ 59098 ] {3c5b0e82-269b-4c45-9423-eb0378d4701d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.259584 [ 59098 ] {f64b833b-0f06-4e0b-ad19-80d8b7d2f4e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET_ATON(NULL, NULL, NULL);) 2025.06.18 11:27:18.266007 [ 59098 ] {f64b833b-0f06-4e0b-ad19-80d8b7d2f4e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.315608 [ 59098 ] {c1ee0bb1-5f35-4173-acd1-09323568072e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET_NTOA(NULL, NULL, NULL);) 2025.06.18 11:27:18.322268 [ 59098 ] {c1ee0bb1-5f35-4173-acd1-09323568072e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.374432 [ 59098 ] {8f152a4f-35da-496e-a6bc-dcad9c6be933} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4CIDRToRange(NULL, NULL, NULL);) 2025.06.18 11:27:18.380181 [ 59098 ] {8f152a4f-35da-496e-a6bc-dcad9c6be933} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.444159 [ 59098 ] {f894045e-c2e6-45a2-ac00-2bf8fba129ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4NumToString(NULL, NULL, NULL);) 2025.06.18 11:27:18.451400 [ 59098 ] {f894045e-c2e6-45a2-ac00-2bf8fba129ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.500218 [ 59098 ] {13820fba-f32f-43c7-a4c2-d1452ff48497} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4NumToStringClassC(NULL, NULL, NULL);) 2025.06.18 11:27:18.505491 [ 59098 ] {13820fba-f32f-43c7-a4c2-d1452ff48497} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.558906 [ 59098 ] {740366ac-c7aa-44b4-861e-d342ae3971bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNum(NULL, NULL, NULL);) 2025.06.18 11:27:18.566838 [ 59098 ] {740366ac-c7aa-44b4-861e-d342ae3971bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.616320 [ 59098 ] {e4bf4003-6541-439e-9199-6893d794487e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL);) 2025.06.18 11:27:18.622701 [ 59098 ] {e4bf4003-6541-439e-9199-6893d794487e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.669724 [ 59098 ] {e3691e9a-acd7-497f-9efe-fb5a0f46c325} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL, NULL);) 2025.06.18 11:27:18.675456 [ 59098 ] {e3691e9a-acd7-497f-9efe-fb5a0f46c325} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.722023 [ 59098 ] {cd55d21a-4c1e-4d46-8c3a-423512791d9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4ToIPv6(NULL, NULL, NULL);) 2025.06.18 11:27:18.727283 [ 59098 ] {cd55d21a-4c1e-4d46-8c3a-423512791d9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.772663 [ 59098 ] {4fb1def7-2c72-4be7-bba2-06add923baef} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6CIDRToRange(NULL, NULL, NULL);) 2025.06.18 11:27:18.778822 [ 59098 ] {4fb1def7-2c72-4be7-bba2-06add923baef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.834447 [ 59098 ] {3c9165a3-44ee-494a-beef-9dd90f4080d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6NumToString(NULL, NULL, NULL);) 2025.06.18 11:27:18.839994 [ 59098 ] {3c9165a3-44ee-494a-beef-9dd90f4080d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.888317 [ 59098 ] {86cf9d24-81e3-450f-81d5-853a3829dded} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNum(NULL, NULL, NULL);) 2025.06.18 11:27:18.894376 [ 59098 ] {86cf9d24-81e3-450f-81d5-853a3829dded} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.947997 [ 59098 ] {39ead811-a14f-45b0-9979-cc02501d0117} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL);) 2025.06.18 11:27:18.955467 [ 59098 ] {39ead811-a14f-45b0-9979-cc02501d0117} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:18.999637 [ 59098 ] {29f4abd8-34db-433d-970b-7cbc88d3995c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL, NULL);) 2025.06.18 11:27:19.006327 [ 59098 ] {29f4abd8-34db-433d-970b-7cbc88d3995c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:19.048587 [ 59098 ] {1145751e-c683-4629-a9a9-83fdef9237ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONAllPaths(NULL, NULL, NULL);) 2025.06.18 11:27:19.053675 [ 59098 ] {1145751e-c683-4629-a9a9-83fdef9237ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:19.102812 [ 59098 ] {b524967e-0521-418a-b7f6-f49bc3418dc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL, NULL);) 2025.06.18 11:27:19.109542 [ 59098 ] {b524967e-0521-418a-b7f6-f49bc3418dc7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:19.152955 [ 59098 ] {e73e86a1-a7eb-4e25-8e7b-0b3eb3bbe6af} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONArrayLength(NULL, NULL, NULL);) 2025.06.18 11:27:19.158022 [ 59098 ] {e73e86a1-a7eb-4e25-8e7b-0b3eb3bbe6af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:19.199240 [ 59098 ] {2d84c620-4618-4c25-a9c8-351f59772974} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONDynamicPaths(NULL, NULL, NULL);) 2025.06.18 11:27:19.204198 [ 59098 ] {2d84c620-4618-4c25-a9c8-351f59772974} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:19.247299 [ 59098 ] {9119170d-caca-4dd7-86e3-2b7625adfce5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL);) 2025.06.18 11:27:19.252655 [ 59098 ] {9119170d-caca-4dd7-86e3-2b7625adfce5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:19.295976 [ 59098 ] {de711f2e-c3d9-4d00-8a0d-49c78fe5ccd3} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONExtract(NULL, NULL, NULL);) 2025.06.18 11:27:19.301293 [ 59098 ] {de711f2e-c3d9-4d00-8a0d-49c78fe5ccd3} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.06.18 11:27:19.723997 [ 59098 ] {2984923f-0e43-46b4-9f79-f827faf2a44e} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL, NULL);) 2025.06.18 11:27:19.730664 [ 59098 ] {2984923f-0e43-46b4-9f79-f827faf2a44e} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.06.18 11:27:20.368706 [ 59098 ] {9463c41a-cf37-463d-b23e-3efe2410cd15} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONSharedDataPaths(NULL, NULL, NULL);) 2025.06.18 11:27:20.373677 [ 59098 ] {9463c41a-cf37-463d-b23e-3efe2410cd15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:20.416222 [ 59098 ] {2072f26f-fa1a-4209-adb6-3597566b5fcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL);) 2025.06.18 11:27:20.421470 [ 59098 ] {2072f26f-fa1a-4209-adb6-3597566b5fcd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:20.447153 [ 58950 ] {bc8f19c3-c72c-4bc7-a582-b3d349a1a1c5} executeQuery: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant TABLE ENGINE ON File. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37988) (comment: 02561_temporary_table_grants.sh) (in query: CREATE TEMPORARY TABLE table_file_02561(name String) ENGINE = File(TabSeparated)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d8fca 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312d8a69 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000312d7613 6. ./build_docker/./src/Access/ContextAccess.cpp:778: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312edb73 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:20.455459 [ 58950 ] {bc8f19c3-c72c-4bc7-a582-b3d349a1a1c5} TCPHandler: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant TABLE ENGINE ON File. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d8fca 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312d8a69 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000312d7613 6. ./build_docker/./src/Access/ContextAccess.cpp:778: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312edb73 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:20.529677 [ 59098 ] {1e78bf4b-99f7-4e4b-8bde-d5ad98d0ac77} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL);) 2025.06.18 11:27:20.534762 [ 59098 ] {1e78bf4b-99f7-4e4b-8bde-d5ad98d0ac77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:20.801909 [ 59098 ] {7ff10b4f-08bc-476d-a914-7276c27293c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Distance(NULL, NULL, NULL);) 2025.06.18 11:27:20.806627 [ 59098 ] {7ff10b4f-08bc-476d-a914-7276c27293c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:20.848595 [ 59098 ] {bc3a0d80-0795-43d7-90a8-b822564b32ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Norm(NULL, NULL, NULL);) 2025.06.18 11:27:20.852876 [ 59098 ] {bc3a0d80-0795-43d7-90a8-b822564b32ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:20.887663 [ 59098 ] {2a2ae60d-4ad2-4a18-a3c3-0cf9c58ae1d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Normalize(NULL, NULL, NULL);) 2025.06.18 11:27:20.895734 [ 59098 ] {2a2ae60d-4ad2-4a18-a3c3-0cf9c58ae1d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:20.930709 [ 59098 ] {3d0ee2dc-4264-4bc9-b3d5-8e76add00b81} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Distance(NULL, NULL, NULL);) 2025.06.18 11:27:20.935089 [ 59098 ] {3d0ee2dc-4264-4bc9-b3d5-8e76add00b81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:20.975735 [ 59098 ] {e23b25a4-cb41-4b57-a952-62ff2b297054} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Norm(NULL, NULL, NULL);) 2025.06.18 11:27:20.980552 [ 59098 ] {e23b25a4-cb41-4b57-a952-62ff2b297054} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.019786 [ 59098 ] {599a703c-6395-4aa0-b5be-c05dc6fa67d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Normalize(NULL, NULL, NULL);) 2025.06.18 11:27:21.025029 [ 59098 ] {599a703c-6395-4aa0-b5be-c05dc6fa67d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.067615 [ 59098 ] {cf6d2d18-c1ff-4da5-959d-e3dfbb86e9f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2SquaredDistance(NULL, NULL, NULL);) 2025.06.18 11:27:21.072413 [ 59098 ] {cf6d2d18-c1ff-4da5-959d-e3dfbb86e9f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.111489 [ 59098 ] {0191933a-9cfe-4263-9012-d03ea58c6a6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2SquaredNorm(NULL, NULL, NULL);) 2025.06.18 11:27:21.116182 [ 59098 ] {0191933a-9cfe-4263-9012-d03ea58c6a6e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.232065 [ 59098 ] {1b415929-c7da-4aa9-a005-59c192b8d540} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfDistance(NULL, NULL, NULL);) 2025.06.18 11:27:21.237034 [ 59098 ] {1b415929-c7da-4aa9-a005-59c192b8d540} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.284401 [ 59098 ] {ef8374e4-bea2-4f3c-a517-e885bca345a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfNorm(NULL, NULL, NULL);) 2025.06.18 11:27:21.289863 [ 59098 ] {ef8374e4-bea2-4f3c-a517-e885bca345a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.332830 [ 59098 ] {d14d85fa-0726-4937-a853-362cf4c05269} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfNormalize(NULL, NULL, NULL);) 2025.06.18 11:27:21.338091 [ 59098 ] {d14d85fa-0726-4937-a853-362cf4c05269} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.465229 [ 59098 ] {926c7371-7708-4521-8682-6a76b7d3af17} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LpNorm(NULL, NULL, NULL);) 2025.06.18 11:27:21.470702 [ 59098 ] {926c7371-7708-4521-8682-6a76b7d3af17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.520259 [ 59098 ] {e9cacc5e-a3ba-4ebd-b6b0-ed476802409c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LpNormalize(NULL, NULL, NULL);) 2025.06.18 11:27:21.525535 [ 59098 ] {e9cacc5e-a3ba-4ebd-b6b0-ed476802409c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.573620 [ 59098 ] {e2bff84b-1165-4d95-8375-ef7786075549} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACNumToString(NULL, NULL, NULL);) 2025.06.18 11:27:21.579900 [ 59098 ] {e2bff84b-1165-4d95-8375-ef7786075549} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.628043 [ 59098 ] {f9f0b912-f518-47b7-99d2-58cb0305fb90} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACStringToNum(NULL, NULL, NULL);) 2025.06.18 11:27:21.633631 [ 59098 ] {f9f0b912-f518-47b7-99d2-58cb0305fb90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.679350 [ 59098 ] {4a94b8f3-b2b0-4a07-832a-6a0706cecf1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACStringToOUI(NULL, NULL, NULL);) 2025.06.18 11:27:21.684465 [ 59098 ] {4a94b8f3-b2b0-4a07-832a-6a0706cecf1d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.728461 [ 59098 ] {5ff2da16-3980-4a3f-b2c3-139e582688e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL);) 2025.06.18 11:27:21.733744 [ 59098 ] {5ff2da16-3980-4a3f-b2c3-139e582688e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.777412 [ 59098 ] {2940897a-5aee-43c2-8f15-fa2a3a841e94} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MD4(NULL, NULL, NULL);) 2025.06.18 11:27:21.782490 [ 59098 ] {2940897a-5aee-43c2-8f15-fa2a3a841e94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:21.827259 [ 59098 ] {9783a27d-9197-4ac3-8f0b-ebb2bf421b05} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MD5(NULL, NULL, NULL);) 2025.06.18 11:27:21.832845 [ 59098 ] {9783a27d-9197-4ac3-8f0b-ebb2bf421b05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.105375 [ 59098 ] {80f37ed9-3ce0-4960-921d-bf219e6e13b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT OCTET_LENGTH(NULL, NULL, NULL);) 2025.06.18 11:27:22.110919 [ 59098 ] {80f37ed9-3ce0-4960-921d-bf219e6e13b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.302184 [ 59098 ] {f15a7171-a511-4762-8ba9-74fdf399afc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT REGEXP_MATCHES(NULL, NULL, NULL);) 2025.06.18 11:27:22.307473 [ 59098 ] {f15a7171-a511-4762-8ba9-74fdf399afc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.432556 [ 59098 ] {417dbcad-9fd9-431f-b7d2-0faac4a37b94} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SCHEMA(NULL, NULL, NULL);) 2025.06.18 11:27:22.438084 [ 59098 ] {417dbcad-9fd9-431f-b7d2-0faac4a37b94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.563000 [ 59098 ] {90369af2-87ef-4f21-a898-316ccedae45a} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA1(NULL, NULL, NULL);) 2025.06.18 11:27:22.569466 [ 59098 ] {90369af2-87ef-4f21-a898-316ccedae45a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.617158 [ 59098 ] {ca26e34d-f2da-44db-88ae-c04c44247ccc} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA224(NULL, NULL, NULL);) 2025.06.18 11:27:22.623293 [ 59098 ] {ca26e34d-f2da-44db-88ae-c04c44247ccc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.669068 [ 59098 ] {bb8dc321-24c2-4609-a94e-8592fd4133bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA256(NULL, NULL, NULL);) 2025.06.18 11:27:22.675447 [ 59098 ] {bb8dc321-24c2-4609-a94e-8592fd4133bc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.728281 [ 59098 ] {2cdb601d-a0a6-4f59-98a3-1d8339d4a113} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA384(NULL, NULL, NULL);) 2025.06.18 11:27:22.735053 [ 59098 ] {2cdb601d-a0a6-4f59-98a3-1d8339d4a113} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.772311 [ 58950 ] {57b3d205-799f-4e00-b3fb-71082d27647d} executeQuery: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant TABLE ENGINE ON URL. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50542) (comment: 02561_temporary_table_grants.sh) (in query: CREATE TEMPORARY TABLE table_url_02561(name String) ENGINE = URL('http://127.0.0.1:8123?query=select+12', 'RawBLOB')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d8fca 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312d8a69 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000312d7613 6. ./build_docker/./src/Access/ContextAccess.cpp:778: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312edb73 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:22.781176 [ 59098 ] {ffada9e4-ed13-497e-8459-af53cf5cad5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA512(NULL, NULL, NULL);) 2025.06.18 11:27:22.788060 [ 59098 ] {ffada9e4-ed13-497e-8459-af53cf5cad5d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.790443 [ 58950 ] {57b3d205-799f-4e00-b3fb-71082d27647d} TCPHandler: Code: 497. DB::Exception: user_02561_temporary_table_grants_test_woqzgl8a: Not enough privileges. To execute this query, it's necessary to have the grant TABLE ENGINE ON URL. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d8fca 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312d8a69 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000312d7613 6. ./build_docker/./src/Access/ContextAccess.cpp:778: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312edb73 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000003129338d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000033729d9b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e62c2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:22.829870 [ 59098 ] {ca2702ed-4ae8-44e3-9037-cd0492461bbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA512_256(NULL, NULL, NULL);) 2025.06.18 11:27:22.837121 [ 59098 ] {ca2702ed-4ae8-44e3-9037-cd0492461bbd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:22.957224 [ 35636 ] {622eda32-8fd0-4357-a1f8-b5e6388e680f} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58280) (comment: 01504_rocksdb.sql) (in query: SELECT k, value FROM 01504_test WHERE k = 0 OR value > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:22.982169 [ 35636 ] {622eda32-8fd0-4357-a1f8-b5e6388e680f} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:23.223149 [ 35636 ] {713e7a03-2c8d-4acf-a083-1060bb2f79d9} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58280) (comment: 01504_rocksdb.sql) (in query: SELECT k, value FROM 01504_test WHERE k = 0 AND k IN (1, 3) OR k > 8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:23.248913 [ 35636 ] {713e7a03-2c8d-4acf-a083-1060bb2f79d9} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000032353d37 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000032353810 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322bd094 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeacb38 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:23.464826 [ 59098 ] {072964e4-f668-47f6-b5bc-598229e443df} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT TO_BASE64(NULL, NULL, NULL);) 2025.06.18 11:27:23.470550 [ 59098 ] {072964e4-f668-47f6-b5bc-598229e443df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:23.853412 [ 59098 ] {3c9263ab-b233-4bd9-bdad-32de2d635de3} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT URLHierarchy(NULL, NULL, NULL);) 2025.06.18 11:27:23.858876 [ 59098 ] {3c9263ab-b233-4bd9-bdad-32de2d635de3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:23.907005 [ 59098 ] {65080f32-850b-414e-875d-8f048b57cacb} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT URLPathHierarchy(NULL, NULL, NULL);) 2025.06.18 11:27:23.913864 [ 59098 ] {65080f32-850b-414e-875d-8f048b57cacb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:23.964447 [ 59098 ] {70a98a6e-42a0-4ec2-a7ba-85b3106a6939} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT UTCTimestamp(NULL, NULL, NULL);) 2025.06.18 11:27:23.971628 [ 59098 ] {70a98a6e-42a0-4ec2-a7ba-85b3106a6939} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:24.022480 [ 59098 ] {28c00b9a-9591-4336-8f5e-feb7cd657189} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT UTC_timestamp(NULL, NULL, NULL);) 2025.06.18 11:27:24.029481 [ 59098 ] {28c00b9a-9591-4336-8f5e-feb7cd657189} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:24.974822 [ 59098 ] {8a500ec9-f126-4431-82ec-eadec637d452} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT _CAST(NULL, NULL, NULL);) 2025.06.18 11:27:24.980558 [ 59098 ] {8a500ec9-f126-4431-82ec-eadec637d452} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.021237 [ 59098 ] {3e0b87d2-5bc1-49f9-b6ec-16f9c53e0954} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __actionName(NULL, NULL, NULL);) 2025.06.18 11:27:25.026463 [ 59098 ] {3e0b87d2-5bc1-49f9-b6ec-16f9c53e0954} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.030245 [ 51843 ] {abb6ece5-ee26-47d0-8afa-d0fa3fb9b8d2} executeQuery: Code: 36. DB::Exception: CellId is invalid.: In scope SELECT s2ToGeo(toUInt64(-1)). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50494) (comment: 01849_geoToS2.sql) (in query: SELECT s2ToGeo(toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf05f04 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:25.031977 [ 51843 ] {abb6ece5-ee26-47d0-8afa-d0fa3fb9b8d2} TCPHandler: Code: 36. DB::Exception: CellId is invalid.: In scope SELECT s2ToGeo(toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bf05f04 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:25.062794 [ 59098 ] {0ae80493-fb81-455a-8ff3-1d4aef206d8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitBoolMaskAnd(NULL, NULL, NULL);) 2025.06.18 11:27:25.067813 [ 59098 ] {0ae80493-fb81-455a-8ff3-1d4aef206d8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.111320 [ 59098 ] {18334539-25ee-45b8-ac25-808c1965efc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitBoolMaskOr(NULL, NULL, NULL);) 2025.06.18 11:27:25.116502 [ 59098 ] {18334539-25ee-45b8-ac25-808c1965efc2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.161030 [ 59098 ] {527db3e8-374c-4039-a1d5-c010caf3bbd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitSwapLastTwo(NULL, NULL, NULL);) 2025.06.18 11:27:25.166192 [ 59098 ] {527db3e8-374c-4039-a1d5-c010caf3bbd5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.208121 [ 59098 ] {3294669a-be4e-4acc-a3b2-27a4569bc507} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitWrapperFunc(NULL, NULL, NULL);) 2025.06.18 11:27:25.214039 [ 59098 ] {3294669a-be4e-4acc-a3b2-27a4569bc507} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.267032 [ 59098 ] {14465f31-2181-431b-acbc-bc73879877e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __getScalar(NULL, NULL, NULL);) 2025.06.18 11:27:25.274112 [ 59098 ] {14465f31-2181-431b-acbc-bc73879877e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.315513 [ 59098 ] {0f312363-2e6b-4ce7-83cf-4833d2a6e68e} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __scalarSubqueryResult(NULL, NULL, NULL);) 2025.06.18 11:27:25.320839 [ 59098 ] {0f312363-2e6b-4ce7-83cf-4833d2a6e68e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.367583 [ 59098 ] {26120bf8-bf89-4dca-931d-e4080bc368cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT abs(NULL, NULL, NULL);) 2025.06.18 11:27:25.373155 [ 59098 ] {26120bf8-bf89-4dca-931d-e4080bc368cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.416960 [ 59098 ] {25f7099f-de73-4e97-b3de-d12c9156aaf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCast(NULL, NULL, NULL);) 2025.06.18 11:27:25.423355 [ 59098 ] {25f7099f-de73-4e97-b3de-d12c9156aaf2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.463944 [ 59098 ] {a29ae1ba-cbda-4b16-89a3-3ef4f6a229a9} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCastOrDefault(NULL, NULL, NULL);) 2025.06.18 11:27:25.469167 [ 59098 ] {a29ae1ba-cbda-4b16-89a3-3ef4f6a229a9} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:25.509633 [ 59098 ] {e21a9707-bccc-416d-891c-3039262e55a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCastOrNull(NULL, NULL, NULL);) 2025.06.18 11:27:25.514891 [ 59098 ] {e21a9707-bccc-416d-891c-3039262e55a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.566548 [ 59098 ] {617e8c34-ce22-46f1-b69f-2aa1829bfbce} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT acos(NULL, NULL, NULL);) 2025.06.18 11:27:25.573075 [ 59098 ] {617e8c34-ce22-46f1-b69f-2aa1829bfbce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.622837 [ 59098 ] {6e848257-fdb7-4322-8e71-108101f0dd48} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT acosh(NULL, NULL, NULL);) 2025.06.18 11:27:25.628942 [ 59098 ] {6e848257-fdb7-4322-8e71-108101f0dd48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.679332 [ 59098 ] {c7cdc938-c9bd-49b4-8cc0-55a6bdcce535} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addDate(NULL, NULL, NULL);) 2025.06.18 11:27:25.685516 [ 59098 ] {c7cdc938-c9bd-49b4-8cc0-55a6bdcce535} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:25.840626 [ 51843 ] {a68a947a-3d04-4ba0-96e9-0935de97db7a} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50494) (comment: 01849_geoToS2.sql) (in query: SELECT s2ToGeo(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000fe6ecd7 4. DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001bf077b5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:27:25.844476 [ 51843 ] {a68a947a-3d04-4ba0-96e9-0935de97db7a} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000fe6ecd7 4. DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001bf077b5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000837a6e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083ce9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b608e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6080da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b609dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a2f8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 2025.06.18 11:27:25.860829 [ 35671 ] {82c5a98f-d79e-4e97-a758-332098f1c035} executeQuery: Code: 497. DB::Exception: u_02015_denied: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(id, s) ON test_mgkk7j54.async_inserts. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54258) (comment: 02015_async_inserts_4.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003363758b 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000033638398 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1077: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a0a34 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:25.866726 [ 35671 ] {82c5a98f-d79e-4e97-a758-332098f1c035} DynamicQueryHandler: Code: 497. DB::Exception: u_02015_denied: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(id, s) ON test_mgkk7j54.async_inserts. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003363758b 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000033638398 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1077: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a0a34 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9fd791 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa09ba8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac30101 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:27:25.903918 [ 59098 ] {85901677-e8ea-4a4b-888d-8c026e6f1050} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addInterval(NULL, NULL, NULL);) 2025.06.18 11:27:25.910031 [ 59098 ] {85901677-e8ea-4a4b-888d-8c026e6f1050} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:26.630677 [ 59098 ] {134c690f-f1af-400b-a9aa-70a1f79c5250} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addTupleOfIntervals(NULL, NULL, NULL);) 2025.06.18 11:27:26.638023 [ 59098 ] {134c690f-f1af-400b-a9aa-70a1f79c5250} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:26.709472 [ 51843 ] {a0787d51-499b-4db4-836d-196f1cd41685} executeQuery: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50494) (comment: 01849_geoToS2.sql) (in query: SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000fe76777 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe753b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:26.713202 [ 51843 ] {a0787d51-499b-4db4-836d-196f1cd41685} TCPHandler: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000fe76777 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe753b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:26.857441 [ 59098 ] {a120d526-cebd-4896-8c9e-cba4a733f90c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToLine(NULL, NULL, NULL);) 2025.06.18 11:27:26.865069 [ 59098 ] {a120d526-cebd-4896-8c9e-cba4a733f90c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:26.915756 [ 59098 ] {6ffd906d-1361-463f-b9ba-3ccf0eb44a52} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToLineWithInlines(NULL, NULL, NULL);) 2025.06.18 11:27:26.924384 [ 59098 ] {6ffd906d-1361-463f-b9ba-3ccf0eb44a52} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:26.971551 [ 59098 ] {41664636-251d-460a-9233-0eb92e19cd2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToSymbol(NULL, NULL, NULL);) 2025.06.18 11:27:26.977874 [ 59098 ] {41664636-251d-460a-9233-0eb92e19cd2d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:27.270653 [ 51854 ] {78445cc3-5319-48bc-96bd-193e45b74891} executeQuery: Code: 440. DB::Exception: LIMIT numeric constant expression is not representable as UInt64. (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT number FROM numbers(10) LIMIT 0 - 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:800: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346baa5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:27.274691 [ 51854 ] {78445cc3-5319-48bc-96bd-193e45b74891} TCPHandler: Code: 440. DB::Exception: LIMIT numeric constant expression is not representable as UInt64. (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:800: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346baa5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:27.394627 [ 51854 ] {18e5bd6b-4fb7-4e27-9980-df6854ff9474} executeQuery: Code: 440. DB::Exception: LIMIT numeric constant expression is not representable as UInt64. (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT number FROM numbers(10) LIMIT 1.5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:800: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346baa5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:27.403749 [ 51854 ] {18e5bd6b-4fb7-4e27-9980-df6854ff9474} TCPHandler: Code: 440. DB::Exception: LIMIT numeric constant expression is not representable as UInt64. (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:800: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346baa5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:27.559575 [ 51843 ] {de84e150-7577-43ca-9f1d-15de2e53eacb} executeQuery: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be NaN: In scope SELECT geoToS2(nan, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50494) (comment: 01849_geoToS2.sql) (in query: SELECT geoToS2(nan, nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe74c0c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:27.562885 [ 51843 ] {de84e150-7577-43ca-9f1d-15de2e53eacb} TCPHandler: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be NaN: In scope SELECT geoToS2(nan, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe74c0c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:27.933208 [ 51854 ] {62840c76-4894-4c20-a6fc-56c38839e75c} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual '1'. In scope SELECT number FROM numbers(10) LIMIT '1'. (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT number FROM numbers(10) LIMIT '1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:27.936937 [ 51854 ] {62840c76-4894-4c20-a6fc-56c38839e75c} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual '1'. In scope SELECT number FROM numbers(10) LIMIT '1'. (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:27.982372 [ 51854 ] {cff8be15-bd7d-4661-92d1-17a1ad6ac886} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(1750228047, 'DateTime'). In scope SELECT number FROM numbers(10) LIMIT now(). (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT number FROM numbers(10) LIMIT now();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:27.986534 [ 51854 ] {cff8be15-bd7d-4661-92d1-17a1ad6ac886} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(1750228047, 'DateTime'). In scope SELECT number FROM numbers(10) LIMIT now(). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.028156 [ 51854 ] {242ae1ec-485c-4022-9fcb-6314864ce7c2} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(20256, 'Date'). In scope SELECT number FROM numbers(10) LIMIT today(). (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT number FROM numbers(10) LIMIT today();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.031295 [ 51854 ] {242ae1ec-485c-4022-9fcb-6314864ce7c2} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(20256, 'Date'). In scope SELECT number FROM numbers(10) LIMIT today(). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.057900 [ 59098 ] {e9cc2ce4-52e3-4edc-9c4e-3dbbfd116b5c} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT anyLast_respect_nulls(NULL, NULL, NULL);) 2025.06.18 11:27:28.062834 [ 59098 ] {e9cc2ce4-52e3-4edc-9c4e-3dbbfd116b5c} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:28.102019 [ 59098 ] {bb012c77-72cf-4243-9862-9f1949363fa2} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT any_respect_nulls(NULL, NULL, NULL);) 2025.06.18 11:27:28.108114 [ 59098 ] {bb012c77-72cf-4243-9862-9f1949363fa2} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:28.258690 [ 51854 ] {1472488e-f6e3-4a86-a083-e146002a9589} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual rand(). In scope SELECT number FROM numbers(10) LIMIT rand(). (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT number FROM numbers(10) LIMIT rand();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.261014 [ 59098 ] {f9bc8c33-a98b-4f32-a7d6-996b4af389ee} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT any_value_respect_nulls(NULL, NULL, NULL);) 2025.06.18 11:27:28.262154 [ 51854 ] {1472488e-f6e3-4a86-a083-e146002a9589} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual rand(). In scope SELECT number FROM numbers(10) LIMIT rand(). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.266846 [ 59098 ] {f9bc8c33-a98b-4f32-a7d6-996b4af389ee} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:28.315767 [ 59098 ] {c2e9293d-9745-440c-8248-f7cfec46fec7} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL);) 2025.06.18 11:27:28.321897 [ 59098 ] {c2e9293d-9745-440c-8248-f7cfec46fec7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:28.428208 [ 51843 ] {5acee6f6-4e30-4c7a-b401-1e015eae69c2} executeQuery: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be infinite: In scope SELECT geoToS2(-inf, 1.1754943508222875e-38). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50494) (comment: 01849_geoToS2.sql) (in query: SELECT geoToS2(-inf, 1.1754943508222875e-38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe74df9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:28.431512 [ 51843 ] {5acee6f6-4e30-4c7a-b401-1e015eae69c2} TCPHandler: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be infinite: In scope SELECT geoToS2(-inf, 1.1754943508222875e-38). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe74df9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083799c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d18bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fce10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fdfaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a3bf2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 2025.06.18 11:27:28.762536 [ 51854 ] {0ec33553-0c9f-4ca1-95bc-836cfe8046d1} executeQuery: Code: 440. DB::Exception: LIMIT numeric constant expression is not representable as UInt64. (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT * FROM numbers(10) LIMIT 0.33 / 0.165 - 0.33 + 0.67;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:800: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346baa5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.766061 [ 51854 ] {0ec33553-0c9f-4ca1-95bc-836cfe8046d1} TCPHandler: Code: 440. DB::Exception: LIMIT numeric constant expression is not representable as UInt64. (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:800: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346baa5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.813740 [ 51854 ] {149d8f9e-465a-4cf1-8b34-daf8707dce27} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(0, 'Date'). In scope SELECT * FROM numbers(10) LIMIT LENGTH('NNN') + COS(0), toDate('0000-00-02'). (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT * FROM numbers(10) LIMIT LENGTH('NNN') + COS(0), toDate('0000-00-02');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.817083 [ 51854 ] {149d8f9e-465a-4cf1-8b34-daf8707dce27} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(0, 'Date'). In scope SELECT * FROM numbers(10) LIMIT LENGTH('NNN') + COS(0), toDate('0000-00-02'). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.861679 [ 51854 ] {3dd52881-4c74-456c-a337-0680d2d15c2e} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(0, 'Date'). In scope SELECT * FROM numbers(10) LIMIT LENGTH('NNN') + COS(0), toDate('0000-00-02'). (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT * FROM numbers(10) LIMIT LENGTH('NNN') + COS(0), toDate('0000-00-02');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:28.865189 [ 51854 ] {3dd52881-4c74-456c-a337-0680d2d15c2e} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual _CAST(0, 'Date'). In scope SELECT * FROM numbers(10) LIMIT LENGTH('NNN') + COS(0), toDate('0000-00-02'). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:29.018062 [ 59098 ] {391c258b-c2aa-42bd-a57b-b78c619797aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 3, should be 2: In scope SELECT arrayAUC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayAUC(NULL, NULL, NULL);) 2025.06.18 11:27:29.023558 [ 59098 ] {391c258b-c2aa-42bd-a57b-b78c619797aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 3, should be 2: In scope SELECT arrayAUC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:29.599000 [ 51854 ] {c6cf6bb7-0cd9-46be-a76a-639acb427d23} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT * FROM numbers(10) LIMIT (a + 5) - a. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT * FROM numbers(10) LIMIT a + 5 - a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342cef0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:29.603789 [ 51854 ] {c6cf6bb7-0cd9-46be-a76a-639acb427d23} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT * FROM numbers(10) LIMIT (a + 5) - a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342cef0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:29.760016 [ 59098 ] {d77eb6e3-4e1e-4274-90de-5bf792cfd331} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayDistinct(NULL, NULL, NULL);) 2025.06.18 11:27:29.765643 [ 59098 ] {d77eb6e3-4e1e-4274-90de-5bf792cfd331} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:29.809685 [ 59098 ] {15937a58-aae0-4f7a-8a5b-64df87dfee31} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayDotProduct(NULL, NULL, NULL);) 2025.06.18 11:27:29.815191 [ 59098 ] {15937a58-aae0-4f7a-8a5b-64df87dfee31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:29.858622 [ 59098 ] {ff58900e-7447-45fd-8443-7dac97702db2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayElement(NULL, NULL, NULL);) 2025.06.18 11:27:29.865721 [ 59098 ] {ff58900e-7447-45fd-8443-7dac97702db2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:29.923331 [ 59098 ] {1a57b4e7-f3cc-4f63-a7d5-0443d05a8a20} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayEnumerate(NULL, NULL, NULL);) 2025.06.18 11:27:29.929352 [ 59098 ] {1a57b4e7-f3cc-4f63-a7d5-0443d05a8a20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:30.293989 [ 51854 ] {f78a286e-5004-4c17-846a-33cbae73b37d} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT * FROM numbers(10) LIMIT a + b. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT * FROM numbers(10) LIMIT a + b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342cef0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:30.297983 [ 51854 ] {f78a286e-5004-4c17-846a-33cbae73b37d} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT * FROM numbers(10) LIMIT a + b. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033490995 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033442766 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342cef0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 26. ? @ 0x00007f8e6ce63ac3 27. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:30.347866 [ 51854 ] {00ff0ddd-c143-4a06-a79a-ac4ff1ddd4bb} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual 'Hello'. In scope SELECT * FROM numbers(10) LIMIT 'Hello'. (INVALID_LIMIT_EXPRESSION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50690) (comment: 00834_limit_with_constant_expressions.sql) (in query: SELECT * FROM numbers(10) LIMIT 'Hello';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:30.352378 [ 51854 ] {00ff0ddd-c143-4a06-a79a-ac4ff1ddd4bb} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual 'Hello'. In scope SELECT * FROM numbers(10) LIMIT 'Hello'. (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009625777 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x000000003346b931 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342d1b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:27:30.828998 [ 59098 ] {4e3b1ad0-2666-4b58-8605-9a1367275b8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayFlatten(NULL, NULL, NULL);) 2025.06.18 11:27:30.835452 [ 59098 ] {4e3b1ad0-2666-4b58-8605-9a1367275b8e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:30.881558 [ 59098 ] {a6b51abb-7c2d-44c7-b504-48b8c7f89aa4} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayFold(NULL, NULL, NULL);) 2025.06.18 11:27:30.887468 [ 59098 ] {a6b51abb-7c2d-44c7-b504-48b8c7f89aa4} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:31.013918 [ 59098 ] {7b2d8694-b993-4ead-88c9-3bc39f5132f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayJaccardIndex(NULL, NULL, NULL);) 2025.06.18 11:27:31.020265 [ 59098 ] {7b2d8694-b993-4ead-88c9-3bc39f5132f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:31.069135 [ 59098 ] {6037a1f7-fa1e-4d04-be81-db47519d186d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayJoin(NULL, NULL, NULL);) 2025.06.18 11:27:31.075069 [ 59098 ] {6037a1f7-fa1e-4d04-be81-db47519d186d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:31.892842 [ 59098 ] {46418b3e-01af-46ae-bc1d-6b212869abc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPopBack(NULL, NULL, NULL);) 2025.06.18 11:27:31.897991 [ 59098 ] {46418b3e-01af-46ae-bc1d-6b212869abc4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:31.935609 [ 59098 ] {2fffc71b-4a10-427e-a0ee-cfcb52b92b17} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPopFront(NULL, NULL, NULL);) 2025.06.18 11:27:31.940726 [ 59098 ] {2fffc71b-4a10-427e-a0ee-cfcb52b92b17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:32.063640 [ 59098 ] {b786ad01-0046-464b-bbee-ac9d2f7e9762} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPushBack(NULL, NULL, NULL);) 2025.06.18 11:27:32.069011 [ 59098 ] {b786ad01-0046-464b-bbee-ac9d2f7e9762} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:32.110736 [ 59098 ] {1c0f3e6f-2098-4fec-a84e-1e8a8937f24a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPushFront(NULL, NULL, NULL);) 2025.06.18 11:27:32.115769 [ 59098 ] {1c0f3e6f-2098-4fec-a84e-1e8a8937f24a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:32.158909 [ 59098 ] {a167e1f5-e1a2-42ee-bad7-76877c68e117} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRandomSample(NULL, NULL, NULL);) 2025.06.18 11:27:32.164094 [ 59098 ] {a167e1f5-e1a2-42ee-bad7-76877c68e117} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:32.206648 [ 59098 ] {c6610d55-7c8d-4239-9041-625c22b8e05e} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayReduce(NULL, NULL, NULL);) 2025.06.18 11:27:32.212235 [ 59098 ] {c6610d55-7c8d-4239-9041-625c22b8e05e} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:32.415122 [ 59098 ] {7e8c2486-1e18-42c5-8e3a-01dfc9904a5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayReverse(NULL, NULL, NULL);) 2025.06.18 11:27:32.420911 [ 59098 ] {7e8c2486-1e18-42c5-8e3a-01dfc9904a5d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:32.717837 [ 59098 ] {9a1bc420-ca01-4217-88ab-e32592628919} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRotateLeft(NULL, NULL, NULL);) 2025.06.18 11:27:32.723798 [ 59098 ] {9a1bc420-ca01-4217-88ab-e32592628919} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:32.767237 [ 59098 ] {f480f18e-bfcd-43d2-9398-450d55e7c14e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRotateRight(NULL, NULL, NULL);) 2025.06.18 11:27:32.773035 [ 59098 ] {f480f18e-bfcd-43d2-9398-450d55e7c14e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:32.964865 [ 59098 ] {659a408f-9e3f-4ee7-9569-ce5237749780} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayShingles(NULL, NULL, NULL);) 2025.06.18 11:27:32.970422 [ 59098 ] {659a408f-9e3f-4ee7-9569-ce5237749780} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:33.600052 [ 59098 ] {b72df134-2ac2-42b4-964a-a13c678ccadd} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayWithConstant(NULL, NULL, NULL);) 2025.06.18 11:27:33.605951 [ 59098 ] {b72df134-2ac2-42b4-964a-a13c678ccadd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:33.857426 [ 59098 ] {3121544c-66df-401e-9255-cc9c22a1c4f8} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT array_concat_agg(NULL, NULL, NULL);) 2025.06.18 11:27:33.863812 [ 59098 ] {3121544c-66df-401e-9255-cc9c22a1c4f8} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:33.904562 [ 59098 ] {1fcfdeb4-b2e3-4135-a6e0-1b291c1a941f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ascii(NULL, NULL, NULL);) 2025.06.18 11:27:33.910232 [ 59098 ] {1fcfdeb4-b2e3-4135-a6e0-1b291c1a941f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:33.953301 [ 59098 ] {7b48c589-a34a-4343-a0dd-3a544f7b0248} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT asin(NULL, NULL, NULL);) 2025.06.18 11:27:33.959461 [ 59098 ] {7b48c589-a34a-4343-a0dd-3a544f7b0248} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.005930 [ 59098 ] {4dfb17dd-5368-4f16-8479-1d80784091da} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT asinh(NULL, NULL, NULL);) 2025.06.18 11:27:34.012643 [ 59098 ] {4dfb17dd-5368-4f16-8479-1d80784091da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.058583 [ 59098 ] {65207c70-7dd9-411b-8c43-4cf25c8308d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT assumeNotNull(NULL, NULL, NULL);) 2025.06.18 11:27:34.065678 [ 59098 ] {65207c70-7dd9-411b-8c43-4cf25c8308d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.120599 [ 59098 ] {c18b1552-2019-44a1-916e-0d1e60150c26} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atan(NULL, NULL, NULL);) 2025.06.18 11:27:34.127228 [ 59098 ] {c18b1552-2019-44a1-916e-0d1e60150c26} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.176328 [ 59098 ] {735480a8-bea3-432c-844b-4a8d6a66c569} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atan2(NULL, NULL, NULL);) 2025.06.18 11:27:34.182614 [ 59098 ] {735480a8-bea3-432c-844b-4a8d6a66c569} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.228065 [ 59098 ] {672acc45-a99f-4b35-b58f-24c171971988} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atanh(NULL, NULL, NULL);) 2025.06.18 11:27:34.233105 [ 59098 ] {672acc45-a99f-4b35-b58f-24c171971988} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.536189 [ 59098 ] {6b34afa0-9995-4518-89c0-62ee48145e20} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base58Decode(NULL, NULL, NULL);) 2025.06.18 11:27:34.542180 [ 59098 ] {6b34afa0-9995-4518-89c0-62ee48145e20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.582739 [ 59098 ] {89ea5ba6-244e-463d-a8b8-aaa3f3d38e78} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base58Encode(NULL, NULL, NULL);) 2025.06.18 11:27:34.587916 [ 59098 ] {89ea5ba6-244e-463d-a8b8-aaa3f3d38e78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.626749 [ 59098 ] {716420e9-a20a-470c-a4b8-df4ab42cbee1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64Decode(NULL, NULL, NULL);) 2025.06.18 11:27:34.631634 [ 59098 ] {716420e9-a20a-470c-a4b8-df4ab42cbee1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.676192 [ 59098 ] {e92975b0-ca2e-45a9-8d95-629b0ba31e05} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64Encode(NULL, NULL, NULL);) 2025.06.18 11:27:34.682021 [ 59098 ] {e92975b0-ca2e-45a9-8d95-629b0ba31e05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.722886 [ 59098 ] {4d599d8e-7349-4394-9394-e7252ccbce49} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64URLDecode(NULL, NULL, NULL);) 2025.06.18 11:27:34.728934 [ 59098 ] {4d599d8e-7349-4394-9394-e7252ccbce49} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.777384 [ 59098 ] {b8dce80d-731b-4186-99d5-a74348283e6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64URLEncode(NULL, NULL, NULL);) 2025.06.18 11:27:34.783498 [ 59098 ] {b8dce80d-731b-4186-99d5-a74348283e6a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.833872 [ 59098 ] {8be74dfa-87fb-4d5d-b7c8-e573e5fd0b1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT basename(NULL, NULL, NULL);) 2025.06.18 11:27:34.840388 [ 59098 ] {8be74dfa-87fb-4d5d-b7c8-e573e5fd0b1f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.889940 [ 59098 ] {b58c465b-7c91-4bfe-94d0-4c9fef5a1d46} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bin(NULL, NULL, NULL);) 2025.06.18 11:27:34.895735 [ 59098 ] {b58c465b-7c91-4bfe-94d0-4c9fef5a1d46} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:34.943912 [ 59098 ] {a3a088ca-ed9a-4181-85c5-5b9b84f5447a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitAnd(NULL, NULL, NULL);) 2025.06.18 11:27:34.950811 [ 59098 ] {a3a088ca-ed9a-4181-85c5-5b9b84f5447a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.001588 [ 59098 ] {e4a0d99e-9786-4235-b556-53561e816a5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitCount(NULL, NULL, NULL);) 2025.06.18 11:27:35.007558 [ 59098 ] {e4a0d99e-9786-4235-b556-53561e816a5d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.052648 [ 59098 ] {50fb1d9e-085b-48a3-bcba-ed9c6e878358} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitHammingDistance(NULL, NULL, NULL);) 2025.06.18 11:27:35.070813 [ 59098 ] {50fb1d9e-085b-48a3-bcba-ed9c6e878358} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.114629 [ 59098 ] {7295460c-f2e5-41ae-ae2e-0c63f0bccd88} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitNot(NULL, NULL, NULL);) 2025.06.18 11:27:35.120628 [ 59098 ] {7295460c-f2e5-41ae-ae2e-0c63f0bccd88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.171654 [ 59098 ] {82f409ad-87d6-4aa8-ab8f-57c40afef52e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitOr(NULL, NULL, NULL);) 2025.06.18 11:27:35.178135 [ 59098 ] {82f409ad-87d6-4aa8-ab8f-57c40afef52e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.226249 [ 59098 ] {d1bd3198-7735-4dff-8c5a-c06f5f4006e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitPositionsToArray(NULL, NULL, NULL);) 2025.06.18 11:27:35.232473 [ 59098 ] {d1bd3198-7735-4dff-8c5a-c06f5f4006e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.299915 [ 59098 ] {0a8e4136-cbc4-41de-a4ba-e14d48fd2637} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitRotateLeft(NULL, NULL, NULL);) 2025.06.18 11:27:35.310490 [ 59098 ] {0a8e4136-cbc4-41de-a4ba-e14d48fd2637} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.373906 [ 59098 ] {5b3306c0-dc70-46bd-8df9-6040fc92282e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitRotateRight(NULL, NULL, NULL);) 2025.06.18 11:27:35.387070 [ 59098 ] {5b3306c0-dc70-46bd-8df9-6040fc92282e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.444782 [ 59098 ] {8bb4a67f-c143-4720-b369-069d8ee34603} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitShiftLeft(NULL, NULL, NULL);) 2025.06.18 11:27:35.450726 [ 59098 ] {8bb4a67f-c143-4720-b369-069d8ee34603} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.490217 [ 59098 ] {006315b7-1901-414e-a6e5-3369e32fd589} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitShiftRight(NULL, NULL, NULL);) 2025.06.18 11:27:35.495575 [ 59098 ] {006315b7-1901-414e-a6e5-3369e32fd589} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.618769 [ 59098 ] {02c5e71c-cfca-4f23-a154-1801d6d7c9b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitTest(NULL, NULL, NULL);) 2025.06.18 11:27:35.623989 [ 59098 ] {02c5e71c-cfca-4f23-a154-1801d6d7c9b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.837497 [ 59098 ] {d0a261e5-3d2a-4aa6-bfb8-8294726cdec4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitXor(NULL, NULL, NULL);) 2025.06.18 11:27:35.845021 [ 59098 ] {d0a261e5-3d2a-4aa6-bfb8-8294726cdec4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.903533 [ 59098 ] {f0520df1-7202-4e4b-b122-7fdee5543be7} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAnd(NULL, NULL, NULL);) 2025.06.18 11:27:35.911508 [ 59098 ] {f0520df1-7202-4e4b-b122-7fdee5543be7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:35.956847 [ 59098 ] {31d878a0-1592-434c-adaf-6237e1918139} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndCardinality(NULL, NULL, NULL);) 2025.06.18 11:27:35.962884 [ 59098 ] {31d878a0-1592-434c-adaf-6237e1918139} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.009524 [ 59098 ] {784196c2-3384-4a1f-bf51-e15d61bb30a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndnot(NULL, NULL, NULL);) 2025.06.18 11:27:36.015034 [ 59098 ] {784196c2-3384-4a1f-bf51-e15d61bb30a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.059434 [ 59098 ] {1c9f1d2a-882d-412c-b5be-d546039ab132} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndnotCardinality(NULL, NULL, NULL);) 2025.06.18 11:27:36.065348 [ 59098 ] {1c9f1d2a-882d-412c-b5be-d546039ab132} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.123336 [ 59098 ] {91cfaf9c-dc4e-4548-a750-f98648b446f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapBuild(NULL, NULL, NULL);) 2025.06.18 11:27:36.131916 [ 59098 ] {91cfaf9c-dc4e-4548-a750-f98648b446f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.185078 [ 59098 ] {de818a3c-2131-4540-ae0e-adf8ef0d11d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapCardinality(NULL, NULL, NULL);) 2025.06.18 11:27:36.194249 [ 59098 ] {de818a3c-2131-4540-ae0e-adf8ef0d11d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.244686 [ 59098 ] {bfc2c170-ce72-4f93-a051-782bc4e9442d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapContains(NULL, NULL, NULL);) 2025.06.18 11:27:36.251668 [ 59098 ] {bfc2c170-ce72-4f93-a051-782bc4e9442d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.308790 [ 59098 ] {c778123a-49d7-4ebd-b049-fdf8dd681a59} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapHasAll(NULL, NULL, NULL);) 2025.06.18 11:27:36.316962 [ 59098 ] {c778123a-49d7-4ebd-b049-fdf8dd681a59} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.361231 [ 59098 ] {611d205d-f815-4d1e-8c3f-a1fb3360e46b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapHasAny(NULL, NULL, NULL);) 2025.06.18 11:27:36.372259 [ 59098 ] {611d205d-f815-4d1e-8c3f-a1fb3360e46b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.429644 [ 59098 ] {762c0bd3-ccca-4872-8517-883e1ab9df2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapMax(NULL, NULL, NULL);) 2025.06.18 11:27:36.435835 [ 59098 ] {762c0bd3-ccca-4872-8517-883e1ab9df2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.482603 [ 59098 ] {8be143a6-2c87-4da7-bc21-366d98023892} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapMin(NULL, NULL, NULL);) 2025.06.18 11:27:36.487940 [ 59098 ] {8be143a6-2c87-4da7-bc21-366d98023892} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.528378 [ 59098 ] {5ddf44ff-0e3c-4269-9bc9-e180966d5bfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapOr(NULL, NULL, NULL);) 2025.06.18 11:27:36.533576 [ 59098 ] {5ddf44ff-0e3c-4269-9bc9-e180966d5bfb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.582252 [ 59098 ] {6b732ba6-800d-4357-977b-d334e40531bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapOrCardinality(NULL, NULL, NULL);) 2025.06.18 11:27:36.588299 [ 59098 ] {6b732ba6-800d-4357-977b-d334e40531bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.795307 [ 59098 ] {6b5b9732-2013-4748-9a3d-bc78e3697e4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapToArray(NULL, NULL, NULL);) 2025.06.18 11:27:36.800306 [ 59098 ] {6b5b9732-2013-4748-9a3d-bc78e3697e4d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:36.940541 [ 59098 ] {7f105666-f243-4c7e-87a5-e2df9ef8439a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapXor(NULL, NULL, NULL);) 2025.06.18 11:27:36.951273 [ 59098 ] {7f105666-f243-4c7e-87a5-e2df9ef8439a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.006621 [ 59098 ] {ae8a5f45-11b2-4c92-bc08-0f9f78dfb62d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapXorCardinality(NULL, NULL, NULL);) 2025.06.18 11:27:37.012638 [ 59098 ] {ae8a5f45-11b2-4c92-bc08-0f9f78dfb62d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.052836 [ 59098 ] {b13cedba-16b2-4f4d-889b-9dfa58bf5065} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmaskToArray(NULL, NULL, NULL);) 2025.06.18 11:27:37.058214 [ 59098 ] {b13cedba-16b2-4f4d-889b-9dfa58bf5065} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.110262 [ 59098 ] {f45ba5dd-a6fb-43ed-a655-9d6b9b5d10ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmaskToList(NULL, NULL, NULL);) 2025.06.18 11:27:37.115701 [ 59098 ] {f45ba5dd-a6fb-43ed-a655-9d6b9b5d10ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.159345 [ 59098 ] {3768767e-dc7a-4fcf-bc96-0c65911d3198} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT blockNumber(NULL, NULL, NULL);) 2025.06.18 11:27:37.164024 [ 59098 ] {3768767e-dc7a-4fcf-bc96-0c65911d3198} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.297370 [ 59098 ] {d39a0abd-ffe8-46fe-ab6b-e48ec607aac3} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT blockSize(NULL, NULL, NULL);) 2025.06.18 11:27:37.301927 [ 59098 ] {d39a0abd-ffe8-46fe-ab6b-e48ec607aac3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.449266 [ 59098 ] {23ee0f57-3f1b-47f4-83f2-e266b7c13651} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT buildId(NULL, NULL, NULL);) 2025.06.18 11:27:37.454867 [ 59098 ] {23ee0f57-3f1b-47f4-83f2-e266b7c13651} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.497690 [ 59098 ] {7e55038e-0b72-4b6d-8bd5-4ea27e810445} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT byteHammingDistance(NULL, NULL, NULL);) 2025.06.18 11:27:37.504751 [ 59098 ] {7e55038e-0b72-4b6d-8bd5-4ea27e810445} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:37.715699 [ 59098 ] {0001e9d4-5c22-4c78-ad26-46b3697d5bd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT byteSwap(NULL, NULL, NULL);) 2025.06.18 11:27:37.721454 [ 59098 ] {0001e9d4-5c22-4c78-ad26-46b3697d5bd0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:38.075017 [ 59098 ] {d6e67836-8892-484a-b7b1-4eadecb32095} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT catboostEvaluate(NULL, NULL, NULL);) 2025.06.18 11:27:38.081008 [ 59098 ] {d6e67836-8892-484a-b7b1-4eadecb32095} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:38.123430 [ 59098 ] {486ea7a2-9ead-4eb0-8888-39c9eff1bfd4} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT categoricalInformationValue(NULL, NULL, NULL);) 2025.06.18 11:27:38.129493 [ 59098 ] {486ea7a2-9ead-4eb0-8888-39c9eff1bfd4} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:38.174654 [ 59098 ] {48892d45-5b2e-4907-88ec-2a2522a4e772} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cbrt(NULL, NULL, NULL);) 2025.06.18 11:27:38.181160 [ 59098 ] {48892d45-5b2e-4907-88ec-2a2522a4e772} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:38.391558 [ 59098 ] {b5aa6a64-090d-4f08-bad0-94c20ca130d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeDay(NULL, NULL, NULL);) 2025.06.18 11:27:38.397687 [ 59098 ] {b5aa6a64-090d-4f08-bad0-94c20ca130d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:38.441624 [ 59098 ] {2e461730-2025-4dc5-a7c0-944afa873c05} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeHour(NULL, NULL, NULL);) 2025.06.18 11:27:38.447506 [ 59098 ] {2e461730-2025-4dc5-a7c0-944afa873c05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:38.492410 [ 59098 ] {91957a8f-46f0-4f32-a56f-aa167ab82d91} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeMinute(NULL, NULL, NULL);) 2025.06.18 11:27:38.499113 [ 59098 ] {91957a8f-46f0-4f32-a56f-aa167ab82d91} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:38.541884 [ 59098 ] {a47572de-6e05-4780-b16c-044b3d9cf0dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeMonth(NULL, NULL, NULL);) 2025.06.18 11:27:38.547443 [ 59098 ] {a47572de-6e05-4780-b16c-044b3d9cf0dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:38.586781 [ 59098 ] {5bbef48d-c53b-4744-a8c0-7448f497223f} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeSecond(NULL, NULL, NULL);) 2025.06.18 11:27:38.591780 [ 59098 ] {5bbef48d-c53b-4744-a8c0-7448f497223f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:38.637693 [ 59098 ] {f02db4d6-e86a-4625-b994-77da866b6745} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeYear(NULL, NULL, NULL);) 2025.06.18 11:27:38.646428 [ 59098 ] {f02db4d6-e86a-4625-b994-77da866b6745} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:39.453155 [ 59098 ] {cadd342e-4982-4717-b897-a72f0d1b863a} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT connectionId(NULL, NULL, NULL);) 2025.06.18 11:27:39.458483 [ 59098 ] {cadd342e-4982-4717-b897-a72f0d1b863a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:39.500259 [ 59098 ] {54fb90e1-2385-4860-8260-e0f9a3147c60} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT connection_id(NULL, NULL, NULL);) 2025.06.18 11:27:39.506832 [ 59098 ] {54fb90e1-2385-4860-8260-e0f9a3147c60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.064979 [ 59098 ] {a434cf8f-74f0-4957-b0c6-e3e451f0b659} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cos(NULL, NULL, NULL);) 2025.06.18 11:27:40.070601 [ 59098 ] {a434cf8f-74f0-4957-b0c6-e3e451f0b659} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.112476 [ 59098 ] {00ca5439-d074-4277-9b4a-01be4556f9b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cosh(NULL, NULL, NULL);) 2025.06.18 11:27:40.118085 [ 59098 ] {00ca5439-d074-4277-9b4a-01be4556f9b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.168702 [ 59098 ] {92ed086e-ebb1-48ee-9144-7f3604b6bbc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cosineDistance(NULL, NULL, NULL);) 2025.06.18 11:27:40.175345 [ 59098 ] {92ed086e-ebb1-48ee-9144-7f3604b6bbc2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.218468 [ 59098 ] {03e1a281-4954-4607-8681-2cef3bd102a5} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT count(NULL, NULL, NULL);) 2025.06.18 11:27:40.224584 [ 59098 ] {03e1a281-4954-4607-8681-2cef3bd102a5} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.272862 [ 59098 ] {0a92705b-d469-46e3-bb5e-ebb25bc8de29} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countDigits(NULL, NULL, NULL);) 2025.06.18 11:27:40.279812 [ 59098 ] {0a92705b-d469-46e3-bb5e-ebb25bc8de29} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.324229 [ 59098 ] {51be3a27-f8ff-4192-9dfe-e2c4087495a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countEqual(NULL, NULL, NULL);) 2025.06.18 11:27:40.330532 [ 59098 ] {51be3a27-f8ff-4192-9dfe-e2c4087495a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.380986 [ 59098 ] {561f9014-4c2a-4067-a207-2bcfb9fc1468} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countMatches(NULL, NULL, NULL);) 2025.06.18 11:27:40.389142 [ 59098 ] {561f9014-4c2a-4067-a207-2bcfb9fc1468} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:40.440865 [ 59098 ] {001cf9e2-b11b-4567-9d75-2b13a6ddd474} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countMatchesCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:27:40.447688 [ 59098 ] {001cf9e2-b11b-4567-9d75-2b13a6ddd474} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.568847 [ 59098 ] {7d1a87fd-548b-4f0e-9d5c-68b084be94a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT curdate(NULL, NULL, NULL);) 2025.06.18 11:27:41.574228 [ 59098 ] {7d1a87fd-548b-4f0e-9d5c-68b084be94a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.614478 [ 59098 ] {1348dc76-9cdd-4c9a-8b18-cbf83ed6ef7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentDatabase(NULL, NULL, NULL);) 2025.06.18 11:27:41.619841 [ 59098 ] {1348dc76-9cdd-4c9a-8b18-cbf83ed6ef7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.660126 [ 59098 ] {a71be6b5-a086-4d1b-b32c-668619d82845} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentProfiles(NULL, NULL, NULL);) 2025.06.18 11:27:41.664925 [ 59098 ] {a71be6b5-a086-4d1b-b32c-668619d82845} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.702338 [ 59098 ] {610742a4-3426-48b7-9f4f-2f5fff1cb3f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentRoles(NULL, NULL, NULL);) 2025.06.18 11:27:41.707091 [ 59098 ] {610742a4-3426-48b7-9f4f-2f5fff1cb3f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.745401 [ 59098 ] {804d3ab6-8191-4b27-a0b1-ee0e575b2f60} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentSchemas(NULL, NULL, NULL);) 2025.06.18 11:27:41.750505 [ 59098 ] {804d3ab6-8191-4b27-a0b1-ee0e575b2f60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.812067 [ 59098 ] {ed6a24f7-a8d7-41d9-a1dd-ab7f9235215e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentUser(NULL, NULL, NULL);) 2025.06.18 11:27:41.819051 [ 59098 ] {ed6a24f7-a8d7-41d9-a1dd-ab7f9235215e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.864336 [ 59098 ] {e0565841-1bf0-4ea8-a08f-6be8024fd922} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_database(NULL, NULL, NULL);) 2025.06.18 11:27:41.869885 [ 59098 ] {e0565841-1bf0-4ea8-a08f-6be8024fd922} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.908872 [ 59098 ] {9b36d546-1e43-4faa-8940-53fc49bdad55} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_date(NULL, NULL, NULL);) 2025.06.18 11:27:41.914546 [ 59098 ] {9b36d546-1e43-4faa-8940-53fc49bdad55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.956133 [ 59098 ] {79a1347c-fe83-4bbd-afec-f0f5ea4de483} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_schemas(NULL, NULL, NULL);) 2025.06.18 11:27:41.961129 [ 59098 ] {79a1347c-fe83-4bbd-afec-f0f5ea4de483} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:41.998959 [ 59098 ] {10a59ea4-7d93-4244-bf49-03e1f1e7aeb8} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_timestamp(NULL, NULL, NULL);) 2025.06.18 11:27:42.003969 [ 59098 ] {10a59ea4-7d93-4244-bf49-03e1f1e7aeb8} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.047382 [ 59098 ] {1c610edc-5be9-48f8-8ea3-6e868a202801} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_user(NULL, NULL, NULL);) 2025.06.18 11:27:42.054069 [ 59098 ] {1c610edc-5be9-48f8-8ea3-6e868a202801} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.098187 [ 59098 ] {af5a03db-5f03-4f53-af2e-455e15a5fe17} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutFragment(NULL, NULL, NULL);) 2025.06.18 11:27:42.103045 [ 59098 ] {af5a03db-5f03-4f53-af2e-455e15a5fe17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.231926 [ 59098 ] {25b5eec8-f8ee-49f7-8b07-811db4399010} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutQueryString(NULL, NULL, NULL);) 2025.06.18 11:27:42.237896 [ 59098 ] {25b5eec8-f8ee-49f7-8b07-811db4399010} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.288794 [ 59098 ] {10056f37-3cee-4e23-a72e-43350b19aa66} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutQueryStringAndFragment(NULL, NULL, NULL);) 2025.06.18 11:27:42.293922 [ 59098 ] {10056f37-3cee-4e23-a72e-43350b19aa66} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.337297 [ 59098 ] {f22e1fad-a525-4ea3-af64-f4599455fc08} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL);) 2025.06.18 11:27:42.343041 [ 59098 ] {f22e1fad-a525-4ea3-af64-f4599455fc08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.392296 [ 59098 ] {cc4d4acd-cbcb-41af-a73f-eed7e463a27c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.06.18 11:27:42.398252 [ 59098 ] {cc4d4acd-cbcb-41af-a73f-eed7e463a27c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.440681 [ 59098 ] {dd644132-2e9c-493e-8aa8-e5ddb9e461d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.06.18 11:27:42.446787 [ 59098 ] {dd644132-2e9c-493e-8aa8-e5ddb9e461d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.492860 [ 59098 ] {25b7ab51-ad7f-4da0-8608-9b962dbee12e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL);) 2025.06.18 11:27:42.497833 [ 59098 ] {25b7ab51-ad7f-4da0-8608-9b962dbee12e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.539974 [ 59098 ] {e23bd1db-bcf3-4c8e-b377-fea0af848c24} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL);) 2025.06.18 11:27:42.553776 [ 59098 ] {e23bd1db-bcf3-4c8e-b377-fea0af848c24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.599783 [ 59098 ] {24a7ab9f-b2a3-45dd-b893-2da69f357947} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.06.18 11:27:42.605562 [ 59098 ] {24a7ab9f-b2a3-45dd-b893-2da69f357947} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.657598 [ 59098 ] {2a3c9a36-135c-4327-b518-a8758b3aaf58} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL);) 2025.06.18 11:27:42.667011 [ 59098 ] {2a3c9a36-135c-4327-b518-a8758b3aaf58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.710516 [ 59098 ] {3c709793-d41e-4655-a6ae-4be6a798d924} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL);) 2025.06.18 11:27:42.716151 [ 59098 ] {3c709793-d41e-4655-a6ae-4be6a798d924} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.753793 [ 59098 ] {58ab0154-23c4-4fb4-a2ad-e01f817a80bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutURLParameter(NULL, NULL, NULL);) 2025.06.18 11:27:42.758953 [ 59098 ] {58ab0154-23c4-4fb4-a2ad-e01f817a80bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.800041 [ 59098 ] {260b1c90-16a8-4dd4-804d-1c0066794d18} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutWWW(NULL, NULL, NULL);) 2025.06.18 11:27:42.805465 [ 59098 ] {260b1c90-16a8-4dd4-804d-1c0066794d18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:42.864270 [ 59098 ] {abbabc4b-585e-4f61-ae88-983acf90d45c} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT damerauLevenshteinDistance(NULL, NULL, NULL);) 2025.06.18 11:27:42.875894 [ 59098 ] {abbabc4b-585e-4f61-ae88-983acf90d45c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.078794 [ 59098 ] {8f98404b-f921-4ac9-836a-530b957d7e26} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dateTime64ToSnowflake(NULL, NULL, NULL);) 2025.06.18 11:27:43.085244 [ 59098 ] {8f98404b-f921-4ac9-836a-530b957d7e26} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.253342 [ 59098 ] {25020f19-0d2a-4274-80d1-4c44bdc0fd74} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dateTimeToSnowflake(NULL, NULL, NULL);) 2025.06.18 11:27:43.259547 [ 59098 ] {25020f19-0d2a-4274-80d1-4c44bdc0fd74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.587667 [ 59098 ] {470d1aaf-a9eb-4a50-98b5-88feeee7e241} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeHTMLComponent(NULL, NULL, NULL);) 2025.06.18 11:27:43.592516 [ 59098 ] {470d1aaf-a9eb-4a50-98b5-88feeee7e241} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.642636 [ 59098 ] {1e9ceeb3-5ba4-4587-bb4a-e4ec4ad7c2f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeURLComponent(NULL, NULL, NULL);) 2025.06.18 11:27:43.663264 [ 59098 ] {1e9ceeb3-5ba4-4587-bb4a-e4ec4ad7c2f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.734208 [ 59098 ] {2a7381e5-f31f-4e89-bbc6-5f172e63e0ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeURLFormComponent(NULL, NULL, NULL);) 2025.06.18 11:27:43.741471 [ 59098 ] {2a7381e5-f31f-4e89-bbc6-5f172e63e0ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.793625 [ 59098 ] {ec2d05ad-47e4-4d27-9e37-ce4f1b5c28b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeXMLComponent(NULL, NULL, NULL);) 2025.06.18 11:27:43.800529 [ 59098 ] {ec2d05ad-47e4-4d27-9e37-ce4f1b5c28b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.929784 [ 59098 ] {e1fb4a75-a64e-4eb2-b350-413af7900728} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultProfiles(NULL, NULL, NULL);) 2025.06.18 11:27:43.935641 [ 59098 ] {e1fb4a75-a64e-4eb2-b350-413af7900728} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:43.978330 [ 59098 ] {57663785-e662-4b37-9247-c3ac128589d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultRoles(NULL, NULL, NULL);) 2025.06.18 11:27:43.983692 [ 59098 ] {57663785-e662-4b37-9247-c3ac128589d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:44.030339 [ 59098 ] {cc86980c-1000-4640-a8b6-fda965209857} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultValueOfArgumentType(NULL, NULL, NULL);) 2025.06.18 11:27:44.036224 [ 59098 ] {cc86980c-1000-4640-a8b6-fda965209857} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:44.081611 [ 59098 ] {8532feca-1a78-45bb-91d0-31410ed25b5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultValueOfTypeName(NULL, NULL, NULL);) 2025.06.18 11:27:44.088141 [ 59098 ] {8532feca-1a78-45bb-91d0-31410ed25b5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:44.137979 [ 59098 ] {985bf331-929e-4777-b165-c057f3c12135} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT degrees(NULL, NULL, NULL);) 2025.06.18 11:27:44.144995 [ 59098 ] {985bf331-929e-4777-b165-c057f3c12135} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:44.186557 [ 59098 ] {bcf5ad13-2a31-41e4-b59a-af954ec537d7} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT deltaSum(NULL, NULL, NULL);) 2025.06.18 11:27:44.192720 [ 59098 ] {bcf5ad13-2a31-41e4-b59a-af954ec537d7} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:44.231909 [ 59098 ] {169f47fe-abba-47a3-b95e-5272c71ee468} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT deltaSumTimestamp(NULL, NULL, NULL);) 2025.06.18 11:27:44.237396 [ 59098 ] {169f47fe-abba-47a3-b95e-5272c71ee468} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:44.284198 [ 59098 ] {33b27d17-bb59-426d-a9c2-d80e12720c65} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT demangle(NULL, NULL, NULL);) 2025.06.18 11:27:44.291008 [ 59098 ] {33b27d17-bb59-426d-a9c2-d80e12720c65} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:44.392808 [ 59098 ] {d508a69f-2027-4e42-a68a-7560ca813ede} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT denseRank(NULL, NULL, NULL);) 2025.06.18 11:27:44.402043 [ 59098 ] {d508a69f-2027-4e42-a68a-7560ca813ede} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:27:44.505222 [ 59098 ] {268bef08-863d-47a1-9712-7d1c56012a52} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dense_rank(NULL, NULL, NULL);) 2025.06.18 11:27:44.518446 [ 59098 ] {268bef08-863d-47a1-9712-7d1c56012a52} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:27:44.576683 [ 59098 ] {c12b08cf-07dc-4d81-aa3e-81cb05f372ff} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectCharset(NULL, NULL, NULL);) 2025.06.18 11:27:44.586892 [ 59098 ] {c12b08cf-07dc-4d81-aa3e-81cb05f372ff} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:27:44.635267 [ 59098 ] {015f0110-16fd-41e6-8303-5607cca5caa5} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguage(NULL, NULL, NULL);) 2025.06.18 11:27:44.641421 [ 59098 ] {015f0110-16fd-41e6-8303-5607cca5caa5} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:27:44.686569 [ 59098 ] {5b3acdd9-5861-4eff-8619-25e9aa7fd946} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguageMixed(NULL, NULL, NULL);) 2025.06.18 11:27:44.692724 [ 59098 ] {5b3acdd9-5861-4eff-8619-25e9aa7fd946} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:27:44.737563 [ 59098 ] {8ff9b904-c458-4d6c-9391-71401a2ee996} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguageUnknown(NULL, NULL, NULL);) 2025.06.18 11:27:44.744203 [ 59098 ] {8ff9b904-c458-4d6c-9391-71401a2ee996} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:27:44.791119 [ 59098 ] {bbaf1af3-d307-4380-b9c3-0be69b4e23f4} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectProgrammingLanguage(NULL, NULL, NULL);) 2025.06.18 11:27:44.796420 [ 59098 ] {bbaf1af3-d307-4380-b9c3-0be69b4e23f4} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:27:44.841991 [ 59098 ] {71b19613-17f8-416a-93c5-958542d37d11} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectTonality(NULL, NULL, NULL);) 2025.06.18 11:27:44.847948 [ 59098 ] {71b19613-17f8-416a-93c5-958542d37d11} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:27:44.896914 [ 59098 ] {2d7dbee4-de3f-4840-922d-2819ce954d0e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGet(NULL, NULL, NULL);) 2025.06.18 11:27:44.907419 [ 59098 ] {2d7dbee4-de3f-4840-922d-2819ce954d0e} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:44.957367 [ 59098 ] {3fd335c6-f63b-43be-88d1-042d239ffd20} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetAll(NULL, NULL, NULL);) 2025.06.18 11:27:44.963267 [ 59098 ] {3fd335c6-f63b-43be-88d1-042d239ffd20} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:45.008438 [ 59098 ] {1418d0b9-1412-4952-83cd-4c37f0edfcbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetChildren(NULL, NULL, NULL);) 2025.06.18 11:27:45.013528 [ 59098 ] {1418d0b9-1412-4952-83cd-4c37f0edfcbf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:45.431036 [ 59098 ] {9c2f36c5-ea6a-498c-8f3f-f555dbb87c41} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetDescendants(NULL, NULL, NULL);) 2025.06.18 11:27:45.462087 [ 59098 ] {9c2f36c5-ea6a-498c-8f3f-f555dbb87c41} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.18 11:27:46.014158 [ 59098 ] {a32fbabb-28f9-4d1f-976e-d83751808f8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetHierarchy(NULL, NULL, NULL);) 2025.06.18 11:27:46.020578 [ 59098 ] {a32fbabb-28f9-4d1f-976e-d83751808f8b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:47.198642 [ 59098 ] {40a222d3-b957-4035-8dcf-706fd9d91047} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetOrDefault(NULL, NULL, NULL);) 2025.06.18 11:27:47.206692 [ 59098 ] {40a222d3-b957-4035-8dcf-706fd9d91047} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:47.267549 [ 59098 ] {99c2965e-76f4-4505-913d-059ab3c5abeb} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetOrNull(NULL, NULL, NULL);) 2025.06.18 11:27:47.274740 [ 59098 ] {99c2965e-76f4-4505-913d-059ab3c5abeb} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:48.445189 [ 59098 ] {ae1fb6f9-48e2-44be-9dff-74d72fc95899} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT displayName(NULL, NULL, NULL);) 2025.06.18 11:27:48.450812 [ 59098 ] {ae1fb6f9-48e2-44be-9dff-74d72fc95899} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.495020 [ 59098 ] {be3b1942-86ca-4e85-bf7e-33c9272324af} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL1(NULL, NULL, NULL);) 2025.06.18 11:27:48.501515 [ 59098 ] {be3b1942-86ca-4e85-bf7e-33c9272324af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.544149 [ 59098 ] {bab09f43-e712-424c-88a7-d5b6566b8afa} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL2(NULL, NULL, NULL);) 2025.06.18 11:27:48.549747 [ 59098 ] {bab09f43-e712-424c-88a7-d5b6566b8afa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.592443 [ 59098 ] {f1bbb9c6-92ef-4fff-a370-2c52c73af6e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL2Squared(NULL, NULL, NULL);) 2025.06.18 11:27:48.597612 [ 59098 ] {f1bbb9c6-92ef-4fff-a370-2c52c73af6e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.640395 [ 59098 ] {3ee31653-ca48-47ae-a674-6ac23fc4737e} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceLinf(NULL, NULL, NULL);) 2025.06.18 11:27:48.646316 [ 59098 ] {3ee31653-ca48-47ae-a674-6ac23fc4737e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.769954 [ 59098 ] {de06f0b6-e7f3-42f7-b1b6-6ef43e552f56} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT divide(NULL, NULL, NULL);) 2025.06.18 11:27:48.776065 [ 59098 ] {de06f0b6-e7f3-42f7-b1b6-6ef43e552f56} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.887532 [ 59098 ] {74ef3362-ccb6-4d6c-a675-e291c3c29d80} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domain(NULL, NULL, NULL);) 2025.06.18 11:27:48.893625 [ 59098 ] {74ef3362-ccb6-4d6c-a675-e291c3c29d80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.937662 [ 59098 ] {6bcea3cb-7bbb-409f-b19f-514ac7523c6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainRFC(NULL, NULL, NULL);) 2025.06.18 11:27:48.944100 [ 59098 ] {6bcea3cb-7bbb-409f-b19f-514ac7523c6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:48.983911 [ 59098 ] {7bae296d-41f9-460e-b9ac-95f9ac4d7b07} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainWithoutWWW(NULL, NULL, NULL);) 2025.06.18 11:27:48.989046 [ 59098 ] {7bae296d-41f9-460e-b9ac-95f9ac4d7b07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.025305 [ 59098 ] {0f06f154-0df2-4bd3-a8e9-4a45229a7546} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainWithoutWWWRFC(NULL, NULL, NULL);) 2025.06.18 11:27:49.030161 [ 59098 ] {0f06f154-0df2-4bd3-a8e9-4a45229a7546} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.066645 [ 59098 ] {f1581ca3-81a9-48bf-a0c8-7d69358f8475} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dotProduct(NULL, NULL, NULL);) 2025.06.18 11:27:49.071762 [ 59098 ] {f1581ca3-81a9-48bf-a0c8-7d69358f8475} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.109425 [ 59098 ] {eca7201b-3d05-4ebc-9245-84aebdbd56e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dumpColumnStructure(NULL, NULL, NULL);) 2025.06.18 11:27:49.114129 [ 59098 ] {eca7201b-3d05-4ebc-9245-84aebdbd56e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.151221 [ 59098 ] {14cef80c-ad86-4f09-8941-3d24825a4fdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dynamicElement(NULL, NULL, NULL);) 2025.06.18 11:27:49.156127 [ 59098 ] {14cef80c-ad86-4f09-8941-3d24825a4fdf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.194765 [ 59098 ] {0a1a4685-40d0-4dad-858a-33580121ef24} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dynamicType(NULL, NULL, NULL);) 2025.06.18 11:27:49.201176 [ 59098 ] {0a1a4685-40d0-4dad-858a-33580121ef24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.240539 [ 59098 ] {ef1e730c-0cc9-4197-8ca4-379bb1888a71} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT e(NULL, NULL, NULL);) 2025.06.18 11:27:49.246281 [ 59098 ] {ef1e730c-0cc9-4197-8ca4-379bb1888a71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.284965 [ 59098 ] {eac8c4dd-cf93-4158-96f7-6fb1ea6f3b5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT editDistance(NULL, NULL, NULL);) 2025.06.18 11:27:49.290381 [ 59098 ] {eac8c4dd-cf93-4158-96f7-6fb1ea6f3b5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.329545 [ 59098 ] {b16bf100-30f6-4738-8c65-55b51f8856ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT editDistanceUTF8(NULL, NULL, NULL);) 2025.06.18 11:27:49.334764 [ 59098 ] {b16bf100-30f6-4738-8c65-55b51f8856ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.373768 [ 59098 ] {4b4cb0fd-5c28-40e6-8516-1e14d7255895} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT empty(NULL, NULL, NULL);) 2025.06.18 11:27:49.379162 [ 59098 ] {4b4cb0fd-5c28-40e6-8516-1e14d7255895} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.423212 [ 59098 ] {b35a467f-778d-4bd4-9391-0aa379208027} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayDate(NULL, NULL, NULL);) 2025.06.18 11:27:49.428018 [ 59098 ] {b35a467f-778d-4bd4-9391-0aa379208027} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.465392 [ 59098 ] {5d4167b3-083e-4bab-82ab-79a3558e6433} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayDateTime(NULL, NULL, NULL);) 2025.06.18 11:27:49.470203 [ 59098 ] {5d4167b3-083e-4bab-82ab-79a3558e6433} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.508881 [ 59098 ] {e5c97dce-1fb5-467a-9c37-869f5cfe6d90} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayFloat32(NULL, NULL, NULL);) 2025.06.18 11:27:49.513387 [ 59098 ] {e5c97dce-1fb5-467a-9c37-869f5cfe6d90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.551583 [ 59098 ] {08f85f3c-f7e0-453c-9662-d8f149b50375} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayFloat64(NULL, NULL, NULL);) 2025.06.18 11:27:49.556311 [ 59098 ] {08f85f3c-f7e0-453c-9662-d8f149b50375} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.593705 [ 59098 ] {124195a7-8028-454a-bee2-b236dfd6bffc} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt16(NULL, NULL, NULL);) 2025.06.18 11:27:49.598462 [ 59098 ] {124195a7-8028-454a-bee2-b236dfd6bffc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.633156 [ 59098 ] {0b20af18-79f7-491c-8f63-a4c3be4cd45e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt32(NULL, NULL, NULL);) 2025.06.18 11:27:49.637554 [ 59098 ] {0b20af18-79f7-491c-8f63-a4c3be4cd45e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.674884 [ 59098 ] {19262c1e-bd78-4bf1-b051-94000b7c9543} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt64(NULL, NULL, NULL);) 2025.06.18 11:27:49.679744 [ 59098 ] {19262c1e-bd78-4bf1-b051-94000b7c9543} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.719259 [ 59098 ] {0a143efe-b6b7-4726-a056-57066054b6f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt8(NULL, NULL, NULL);) 2025.06.18 11:27:49.724898 [ 59098 ] {0a143efe-b6b7-4726-a056-57066054b6f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.765051 [ 59098 ] {f615652c-719f-449b-b40c-32b2328ae607} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayString(NULL, NULL, NULL);) 2025.06.18 11:27:49.770536 [ 59098 ] {f615652c-719f-449b-b40c-32b2328ae607} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.809004 [ 59098 ] {1c9d98d0-e304-4504-8283-f4222c34506f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayToSingle(NULL, NULL, NULL);) 2025.06.18 11:27:49.814329 [ 59098 ] {1c9d98d0-e304-4504-8283-f4222c34506f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.853550 [ 59098 ] {64658434-c5c5-42f2-8ef6-1b6bad75ec81} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt16(NULL, NULL, NULL);) 2025.06.18 11:27:49.858794 [ 59098 ] {64658434-c5c5-42f2-8ef6-1b6bad75ec81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.905223 [ 59098 ] {99298841-ac25-400c-a724-132a9cc09e48} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt32(NULL, NULL, NULL);) 2025.06.18 11:27:49.911046 [ 59098 ] {99298841-ac25-400c-a724-132a9cc09e48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:49.953314 [ 59098 ] {32e280eb-6a35-4ed9-8fa0-724e95568c84} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt64(NULL, NULL, NULL);) 2025.06.18 11:27:49.958696 [ 59098 ] {32e280eb-6a35-4ed9-8fa0-724e95568c84} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.002507 [ 59098 ] {05805d08-73f4-4849-bfb9-31924bdb535f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt8(NULL, NULL, NULL);) 2025.06.18 11:27:50.008108 [ 59098 ] {05805d08-73f4-4849-bfb9-31924bdb535f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.051945 [ 59098 ] {1df69acd-e623-463e-b5b6-924fb2c1e797} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT enabledProfiles(NULL, NULL, NULL);) 2025.06.18 11:27:50.058205 [ 59098 ] {1df69acd-e623-463e-b5b6-924fb2c1e797} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.104659 [ 59098 ] {b229558c-e4df-4ebe-942a-e4850a77c9ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT enabledRoles(NULL, NULL, NULL);) 2025.06.18 11:27:50.109489 [ 59098 ] {b229558c-e4df-4ebe-942a-e4850a77c9ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.146621 [ 59098 ] {92407c86-d246-4008-a24d-d4b52889725a} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeURLComponent(NULL, NULL, NULL);) 2025.06.18 11:27:50.151982 [ 59098 ] {92407c86-d246-4008-a24d-d4b52889725a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.197954 [ 59098 ] {3c23a0ba-e8a5-4a9f-9885-e41ef7dda5c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeURLFormComponent(NULL, NULL, NULL);) 2025.06.18 11:27:50.203729 [ 59098 ] {3c23a0ba-e8a5-4a9f-9885-e41ef7dda5c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.245629 [ 59098 ] {a97a6795-33f3-4ce0-8758-f553939697e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeXMLComponent(NULL, NULL, NULL);) 2025.06.18 11:27:50.250711 [ 59098 ] {a97a6795-33f3-4ce0-8758-f553939697e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.357893 [ 59098 ] {05712512-882a-4f55-ac2e-24cce2f1a404} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT endsWith(NULL, NULL, NULL);) 2025.06.18 11:27:50.363455 [ 59098 ] {05712512-882a-4f55-ac2e-24cce2f1a404} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.408787 [ 59098 ] {8e14a16a-376b-4af1-aa36-9d178eca6338} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT endsWithUTF8(NULL, NULL, NULL);) 2025.06.18 11:27:50.414068 [ 59098 ] {8e14a16a-376b-4af1-aa36-9d178eca6338} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.568577 [ 59098 ] {cd2301df-6440-46f9-944c-57395a8cab0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT equals(NULL, NULL, NULL);) 2025.06.18 11:27:50.574631 [ 59098 ] {cd2301df-6440-46f9-944c-57395a8cab0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.624628 [ 59098 ] {9c93d4f7-bb8f-4fb4-ac61-4ee741cb40d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT erf(NULL, NULL, NULL);) 2025.06.18 11:27:50.630123 [ 59098 ] {9c93d4f7-bb8f-4fb4-ac61-4ee741cb40d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.677707 [ 59098 ] {3bec573f-e522-4bc2-b122-8606d4db1f68} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT erfc(NULL, NULL, NULL);) 2025.06.18 11:27:50.683456 [ 59098 ] {3bec573f-e522-4bc2-b122-8606d4db1f68} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.733394 [ 59098 ] {fcf8afe5-4a7e-4d22-abcb-a8bed6116aac} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT errorCodeToName(NULL, NULL, NULL);) 2025.06.18 11:27:50.740404 [ 59098 ] {fcf8afe5-4a7e-4d22-abcb-a8bed6116aac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.870347 [ 59098 ] {bacb5eef-cf95-4401-bc4e-7fa797fa6bfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp(NULL, NULL, NULL);) 2025.06.18 11:27:50.875618 [ 59098 ] {bacb5eef-cf95-4401-bc4e-7fa797fa6bfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.919522 [ 59098 ] {1bf55aba-f74c-41b8-8963-0f0825014d22} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp10(NULL, NULL, NULL);) 2025.06.18 11:27:50.926578 [ 59098 ] {1bf55aba-f74c-41b8-8963-0f0825014d22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:50.968033 [ 59098 ] {745f1832-16f2-4a8b-a064-52da5a86f203} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp2(NULL, NULL, NULL);) 2025.06.18 11:27:50.973244 [ 59098 ] {745f1832-16f2-4a8b-a064-52da5a86f203} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.122231 [ 59098 ] {8519d36c-0d97-47bf-b262-3c4cb7f68e21} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL, NULL);) 2025.06.18 11:27:51.127583 [ 59098 ] {8519d36c-0d97-47bf-b262-3c4cb7f68e21} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.170214 [ 59098 ] {1dba2ad4-d409-4144-9db3-28abb402305d} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL, NULL);) 2025.06.18 11:27:51.175791 [ 59098 ] {1dba2ad4-d409-4144-9db3-28abb402305d} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.224346 [ 59098 ] {5f45d4f6-3f22-4e6e-8f3d-eb767501dd6c} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL, NULL);) 2025.06.18 11:27:51.230467 [ 59098 ] {5f45d4f6-3f22-4e6e-8f3d-eb767501dd6c} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.272024 [ 59098 ] {536af1ec-6b48-43d6-86c8-8d9c71925fb0} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL, NULL);) 2025.06.18 11:27:51.278091 [ 59098 ] {536af1ec-6b48-43d6-86c8-8d9c71925fb0} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.322685 [ 59098 ] {1d459463-590d-4784-aedd-036588d7eadd} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extract(NULL, NULL, NULL);) 2025.06.18 11:27:51.328362 [ 59098 ] {1d459463-590d-4784-aedd-036588d7eadd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.364135 [ 59098 ] {60f06675-c1b6-4222-a8fb-2b8063422973} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAll(NULL, NULL, NULL);) 2025.06.18 11:27:51.368958 [ 59098 ] {60f06675-c1b6-4222-a8fb-2b8063422973} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.415089 [ 59098 ] {e46c095b-5a7c-4400-a58c-343c6ef8a9ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroups(NULL, NULL, NULL);) 2025.06.18 11:27:51.420302 [ 59098 ] {e46c095b-5a7c-4400-a58c-343c6ef8a9ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.466215 [ 59098 ] {2a07dc11-aa5e-4242-953d-9b5bc9f17c77} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroupsHorizontal(NULL, NULL, NULL);) 2025.06.18 11:27:51.472794 [ 59098 ] {2a07dc11-aa5e-4242-953d-9b5bc9f17c77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.523754 [ 59098 ] {e5b11f5e-1980-422b-86d6-8563f49f9633} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroupsVertical(NULL, NULL, NULL);) 2025.06.18 11:27:51.529253 [ 59098 ] {e5b11f5e-1980-422b-86d6-8563f49f9633} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.569193 [ 59098 ] {409af406-8d09-48be-a352-b1d64714c218} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractGroups(NULL, NULL, NULL);) 2025.06.18 11:27:51.575185 [ 59098 ] {409af406-8d09-48be-a352-b1d64714c218} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.818037 [ 59098 ] {095a6ee7-6c7f-490a-9ba5-ca9a2e490c0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractTextFromHTML(NULL, NULL, NULL);) 2025.06.18 11:27:51.823865 [ 59098 ] {095a6ee7-6c7f-490a-9ba5-ca9a2e490c0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.869940 [ 59098 ] {222aa6b1-69e0-420d-bd6d-32362d9d7ac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameter(NULL, NULL, NULL);) 2025.06.18 11:27:51.875595 [ 59098 ] {222aa6b1-69e0-420d-bd6d-32362d9d7ac1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.919252 [ 59098 ] {5e1926e7-ae38-43e0-8391-818e4bc2b7b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameterNames(NULL, NULL, NULL);) 2025.06.18 11:27:51.924124 [ 59098 ] {5e1926e7-ae38-43e0-8391-818e4bc2b7b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:51.968677 [ 59098 ] {b07bd570-a720-4bf5-96a2-5e05b41d8b5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameters(NULL, NULL, NULL);) 2025.06.18 11:27:51.975019 [ 59098 ] {b07bd570-a720-4bf5-96a2-5e05b41d8b5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.021698 [ 59098 ] {fcd11a87-5586-44cd-a0bf-f6107141cf58} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT factorial(NULL, NULL, NULL);) 2025.06.18 11:27:52.027647 [ 59098 ] {fcd11a87-5586-44cd-a0bf-f6107141cf58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.244639 [ 59098 ] {c07d6abf-03c6-4b63-aa6f-993b9046287f} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT file(NULL, NULL, NULL);) 2025.06.18 11:27:52.250550 [ 59098 ] {c07d6abf-03c6-4b63-aa6f-993b9046287f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.519935 [ 59098 ] {b1f455f5-e6cd-4a8e-8514-eb01dacda35e} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT finalizeAggregation(NULL, NULL, NULL);) 2025.06.18 11:27:52.524763 [ 59098 ] {b1f455f5-e6cd-4a8e-8514-eb01dacda35e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.560077 [ 59098 ] {48581d6f-3747-4a59-9694-00719b05551d} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstLine(NULL, NULL, NULL);) 2025.06.18 11:27:52.564850 [ 59098 ] {48581d6f-3747-4a59-9694-00719b05551d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.602313 [ 59098 ] {d981fcdb-4a17-412d-b990-2d30ca18dfed} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomain(NULL, NULL, NULL);) 2025.06.18 11:27:52.607440 [ 59098 ] {d981fcdb-4a17-412d-b990-2d30ca18dfed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.645493 [ 59098 ] {276baa41-44ba-4c5b-876b-b043c31c6f53} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.06.18 11:27:52.650248 [ 59098 ] {276baa41-44ba-4c5b-876b-b043c31c6f53} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.687227 [ 59098 ] {1a3f417e-24c2-4f91-800d-975eb2e3043e} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.06.18 11:27:52.692471 [ 59098 ] {1a3f417e-24c2-4f91-800d-975eb2e3043e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.731561 [ 59098 ] {0887672b-5943-43b1-9bc7-0528a21e992b} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.06.18 11:27:52.736656 [ 59098 ] {0887672b-5943-43b1-9bc7-0528a21e992b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.864116 [ 59098 ] {dbacf7a3-b283-432b-af29-7e370f0cd75f} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT first_value_respect_nulls(NULL, NULL, NULL);) 2025.06.18 11:27:52.869492 [ 59098 ] {dbacf7a3-b283-432b-af29-7e370f0cd75f} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.906863 [ 59098 ] {3fde35d1-5277-4d12-b81c-3d97cec9e958} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flameGraph(NULL, NULL, NULL);) 2025.06.18 11:27:52.911490 [ 59098 ] {3fde35d1-5277-4d12-b81c-3d97cec9e958} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:52.948338 [ 59098 ] {0e670b8d-a66a-4924-919a-a205cc740a09} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flatten(NULL, NULL, NULL);) 2025.06.18 11:27:52.953303 [ 59098 ] {0e670b8d-a66a-4924-919a-a205cc740a09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:52.990357 [ 59098 ] {b3618ff5-171d-4bac-8721-d7d6930a904c} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flattenTuple(NULL, NULL, NULL);) 2025.06.18 11:27:52.995523 [ 59098 ] {b3618ff5-171d-4bac-8721-d7d6930a904c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.345997 [ 59098 ] {469b86a9-8c99-4f86-b254-b534274018a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuery(NULL, NULL, NULL);) 2025.06.18 11:27:53.351004 [ 59098 ] {469b86a9-8c99-4f86-b254-b534274018a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.397089 [ 59098 ] {53b8b6e9-4e7f-4e8b-8fcd-b78b1aeb82f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQueryOrNull(NULL, NULL, NULL);) 2025.06.18 11:27:53.415320 [ 59098 ] {53b8b6e9-4e7f-4e8b-8fcd-b78b1aeb82f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.458645 [ 59098 ] {008a4c8c-94a6-459a-8339-bc1ec773291f} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuerySingleLine(NULL, NULL, NULL);) 2025.06.18 11:27:53.463877 [ 59098 ] {008a4c8c-94a6-459a-8339-bc1ec773291f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.503446 [ 59098 ] {fa354b69-f538-4846-95ea-c7fda19ec488} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL);) 2025.06.18 11:27:53.508406 [ 59098 ] {fa354b69-f538-4846-95ea-c7fda19ec488} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.548026 [ 59098 ] {c2294f11-81a2-4c5c-ade0-eb22d7b1b8b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableDecimalSize(NULL, NULL, NULL);) 2025.06.18 11:27:53.553427 [ 59098 ] {c2294f11-81a2-4c5c-ade0-eb22d7b1b8b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.590963 [ 59098 ] {510a0e5c-208e-465c-8467-bc751e69311e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableQuantity(NULL, NULL, NULL);) 2025.06.18 11:27:53.599306 [ 59098 ] {510a0e5c-208e-465c-8467-bc751e69311e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.670824 [ 59098 ] {aeb68eee-d935-48fc-b79c-d3094d514440} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableSize(NULL, NULL, NULL);) 2025.06.18 11:27:53.677572 [ 59098 ] {aeb68eee-d935-48fc-b79c-d3094d514440} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.800451 [ 59098 ] {ef442bbd-10c7-4e87-a188-24abf8f6ca11} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatRow(NULL, NULL, NULL);) 2025.06.18 11:27:53.806012 [ 59098 ] {ef442bbd-10c7-4e87-a188-24abf8f6ca11} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:53.845599 [ 59098 ] {088c4220-bc37-4b0c-9d3f-3bfd97d4c29e} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatRowNoNewline(NULL, NULL, NULL);) 2025.06.18 11:27:53.850517 [ 59098 ] {088c4220-bc37-4b0c-9d3f-3bfd97d4c29e} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:27:53.887938 [ 59098 ] {1dee90d1-2f10-4247-8022-f5ec74fbb53e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fragment(NULL, NULL, NULL);) 2025.06.18 11:27:53.893301 [ 59098 ] {1dee90d1-2f10-4247-8022-f5ec74fbb53e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.933586 [ 59098 ] {7cdba4d8-3d48-46db-934d-74f671ecfa45} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromDaysSinceYearZero(NULL, NULL, NULL);) 2025.06.18 11:27:53.939050 [ 59098 ] {7cdba4d8-3d48-46db-934d-74f671ecfa45} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:53.978395 [ 59098 ] {29d56db2-b62f-409f-915e-945b89431762} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL, NULL);) 2025.06.18 11:27:53.983407 [ 59098 ] {29d56db2-b62f-409f-915e-945b89431762} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.021323 [ 59098 ] {cdbe0eb0-bc20-400f-befd-8bdfcad825fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromModifiedJulianDay(NULL, NULL, NULL);) 2025.06.18 11:27:54.026838 [ 59098 ] {cdbe0eb0-bc20-400f-befd-8bdfcad825fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.065838 [ 59098 ] {1ad2b4ae-db44-4d23-b64a-7b722a290ab8} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.06.18 11:27:54.070909 [ 59098 ] {1ad2b4ae-db44-4d23-b64a-7b722a290ab8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.113227 [ 59098 ] {4b9fa581-6b8e-493f-a822-cd4423a7a127} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromUTCTimestamp(NULL, NULL, NULL);) 2025.06.18 11:27:54.118645 [ 59098 ] {4b9fa581-6b8e-493f-a822-cd4423a7a127} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.546032 [ 59098 ] {5aad187e-1acc-47b0-ad18-5a03475d138a} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT from_utc_timestamp(NULL, NULL, NULL);) 2025.06.18 11:27:54.551134 [ 59098 ] {5aad187e-1acc-47b0-ad18-5a03475d138a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.593843 [ 59098 ] {ab98a0c3-e573-4ea1-ba8c-1fe7e4dc26cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fullHostName(NULL, NULL, NULL);) 2025.06.18 11:27:54.599518 [ 59098 ] {ab98a0c3-e573-4ea1-ba8c-1fe7e4dc26cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.644040 [ 59098 ] {ed835664-427c-40cc-bb33-eb1f7557bbaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fuzzBits(NULL, NULL, NULL);) 2025.06.18 11:27:54.649437 [ 59098 ] {ed835664-427c-40cc-bb33-eb1f7557bbaf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.769691 [ 59098 ] {54b9b9ed-825b-4433-8c89-6296978dd398} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT gcd(NULL, NULL, NULL);) 2025.06.18 11:27:54.775315 [ 59098 ] {54b9b9ed-825b-4433-8c89-6296978dd398} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.815142 [ 59098 ] {ee72684e-ae44-420f-95e2-9390fecfb0d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateRandomStructure(NULL, NULL, NULL);) 2025.06.18 11:27:54.820058 [ 59098 ] {ee72684e-ae44-420f-95e2-9390fecfb0d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.855407 [ 59098 ] {1e9aac2a-badc-4802-bf6a-421397d7fe53} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateSnowflakeID(NULL, NULL, NULL);) 2025.06.18 11:27:54.860288 [ 59098 ] {1e9aac2a-badc-4802-bf6a-421397d7fe53} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:54.972347 [ 59098 ] {1e2c2f11-4e1c-496c-9335-58f1dc75d731} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateUUIDv4(NULL, NULL, NULL);) 2025.06.18 11:27:54.977983 [ 59098 ] {1e2c2f11-4e1c-496c-9335-58f1dc75d731} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.017553 [ 59098 ] {873598ac-c57e-4f65-8a00-fd43c2809f69} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateUUIDv7(NULL, NULL, NULL);) 2025.06.18 11:27:55.023562 [ 59098 ] {873598ac-c57e-4f65-8a00-fd43c2809f69} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.063572 [ 59098 ] {8cc208bd-18b0-45fd-ab6f-cc84de6a4a2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geoDistance(NULL, NULL, NULL);) 2025.06.18 11:27:55.069739 [ 59098 ] {8cc208bd-18b0-45fd-ab6f-cc84de6a4a2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.194176 [ 59098 ] {5214dde0-9c31-4372-a2d0-93634de4f91b} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geoToS2(NULL, NULL, NULL);) 2025.06.18 11:27:55.200763 [ 59098 ] {5214dde0-9c31-4372-a2d0-93634de4f91b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.240042 [ 59098 ] {5263439c-8d24-41d4-9604-427bb53f2cfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geohashDecode(NULL, NULL, NULL);) 2025.06.18 11:27:55.246877 [ 59098 ] {5263439c-8d24-41d4-9604-427bb53f2cfb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.368311 [ 59098 ] {ea1e2ac3-9901-4b32-950b-cc0d193bce0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geohashesInBox(NULL, NULL, NULL);) 2025.06.18 11:27:55.373851 [ 59098 ] {ea1e2ac3-9901-4b32-950b-cc0d193bce0d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.415819 [ 59098 ] {1bf72cd8-3abb-4127-8f6f-31d7797f48a8} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getClientHTTPHeader(NULL, NULL, NULL);) 2025.06.18 11:27:55.420581 [ 59098 ] {1bf72cd8-3abb-4127-8f6f-31d7797f48a8} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.18 11:27:55.460582 [ 59098 ] {d321808d-04b9-4b67-8f22-282335852ad3} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getMacro(NULL, NULL, NULL);) 2025.06.18 11:27:55.466360 [ 59098 ] {d321808d-04b9-4b67-8f22-282335852ad3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.508696 [ 59098 ] {cacc5ec9-3777-43be-8bd2-2dc1befc4d51} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getOSKernelVersion(NULL, NULL, NULL);) 2025.06.18 11:27:55.514243 [ 59098 ] {cacc5ec9-3777-43be-8bd2-2dc1befc4d51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.555222 [ 59098 ] {74c71eb6-48c6-45c3-9d53-94dab221ecac} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getServerPort(NULL, NULL, NULL);) 2025.06.18 11:27:55.561367 [ 59098 ] {74c71eb6-48c6-45c3-9d53-94dab221ecac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.602910 [ 59098 ] {bc84022e-4d44-40d8-bf37-bf51d06aded5} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSetting(NULL, NULL, NULL);) 2025.06.18 11:27:55.608594 [ 59098 ] {bc84022e-4d44-40d8-bf37-bf51d06aded5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.655333 [ 59098 ] {5484c0a0-c72b-437b-b39a-23b939f370a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSizeOfEnumType(NULL, NULL, NULL);) 2025.06.18 11:27:55.662116 [ 59098 ] {5484c0a0-c72b-437b-b39a-23b939f370a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.704140 [ 59098 ] {5b59e6c4-dfd8-432d-aeb9-19c92a89a019} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSubcolumn(NULL, NULL, NULL);) 2025.06.18 11:27:55.710502 [ 59098 ] {5b59e6c4-dfd8-432d-aeb9-19c92a89a019} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.751026 [ 59098 ] {9363e71e-66b3-4166-bcbc-0e5971f4ba75} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getTypeSerializationStreams(NULL, NULL, NULL);) 2025.06.18 11:27:55.756396 [ 59098 ] {9363e71e-66b3-4166-bcbc-0e5971f4ba75} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.799750 [ 59098 ] {041e16eb-7e17-4e18-bdc0-0592416fc782} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalIn(NULL, NULL, NULL);) 2025.06.18 11:27:55.805770 [ 59098 ] {041e16eb-7e17-4e18-bdc0-0592416fc782} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.843402 [ 59098 ] {3c493b33-1220-47f0-98f6-06bb635a9146} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalInIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:27:55.849371 [ 59098 ] {3c493b33-1220-47f0-98f6-06bb635a9146} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.891855 [ 59098 ] {65cb309b-8c40-443a-a3c2-c89bd30a6c79} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotIn(NULL, NULL, NULL);) 2025.06.18 11:27:55.899259 [ 59098 ] {65cb309b-8c40-443a-a3c2-c89bd30a6c79} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.939314 [ 59098 ] {5693183c-4e34-4e28-a166-9f3b22fbd36d} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotInIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:27:55.945381 [ 59098 ] {5693183c-4e34-4e28-a166-9f3b22fbd36d} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:55.990203 [ 59098 ] {c901e50a-1fad-4f8e-a2b2-438eabb18ca1} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotNullIn(NULL, NULL, NULL);) 2025.06.18 11:27:55.995672 [ 59098 ] {c901e50a-1fad-4f8e-a2b2-438eabb18ca1} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.053892 [ 59098 ] {52ba6bd7-ade9-4c4e-ab31-5e59de7646e3} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotNullInIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:27:56.059963 [ 59098 ] {52ba6bd7-ade9-4c4e-ab31-5e59de7646e3} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.097752 [ 59098 ] {c760b813-994b-4769-b395-f66da370f0df} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNullIn(NULL, NULL, NULL);) 2025.06.18 11:27:56.103368 [ 59098 ] {c760b813-994b-4769-b395-f66da370f0df} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.143340 [ 59098 ] {b565be09-bebc-4120-8965-ef975afeef83} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNullInIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:27:56.148203 [ 59098 ] {b565be09-bebc-4120-8965-ef975afeef83} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.184826 [ 59098 ] {38e57c64-576c-4a24-8a2b-64b56e56da04} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalVariable(NULL, NULL, NULL);) 2025.06.18 11:27:56.189887 [ 59098 ] {38e57c64-576c-4a24-8a2b-64b56e56da04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.228186 [ 59098 ] {f226a51e-e060-42c6-9d20-afaf854a0c13} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greatCircleAngle(NULL, NULL, NULL);) 2025.06.18 11:27:56.233845 [ 59098 ] {f226a51e-e060-42c6-9d20-afaf854a0c13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.269839 [ 59098 ] {4f276719-d46a-4b9b-85ae-afd1909e29a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greatCircleDistance(NULL, NULL, NULL);) 2025.06.18 11:27:56.274428 [ 59098 ] {4f276719-d46a-4b9b-85ae-afd1909e29a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.310741 [ 59098 ] {0a1b6d68-342d-4ee1-ab7e-62bd21976e90} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greater(NULL, NULL, NULL);) 2025.06.18 11:27:56.315338 [ 59098 ] {0a1b6d68-342d-4ee1-ab7e-62bd21976e90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:56.351357 [ 59098 ] {60e182dc-1600-439d-b876-4e883f288453} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greaterOrEquals(NULL, NULL, NULL);) 2025.06.18 11:27:56.356167 [ 59098 ] {60e182dc-1600-439d-b876-4e883f288453} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.097119 [ 59098 ] {dea6b2f8-ada8-498d-b8cd-9b74f7e9c800} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3CellAreaM2(NULL, NULL, NULL);) 2025.06.18 11:27:58.101994 [ 59098 ] {dea6b2f8-ada8-498d-b8cd-9b74f7e9c800} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.141146 [ 59098 ] {8e108a01-83d3-4b8f-9dfc-ab877a4dd295} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3CellAreaRads2(NULL, NULL, NULL);) 2025.06.18 11:27:58.146358 [ 59098 ] {8e108a01-83d3-4b8f-9dfc-ab877a4dd295} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.180653 [ 59098 ] {f0e7f15c-51c3-483c-aa7f-66603de52e6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3Distance(NULL, NULL, NULL);) 2025.06.18 11:27:58.185559 [ 59098 ] {f0e7f15c-51c3-483c-aa7f-66603de52e6e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.228640 [ 59098 ] {daa0b46b-c257-4f9e-9d91-ab4a89739ec0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeAngle(NULL, NULL, NULL);) 2025.06.18 11:27:58.233965 [ 59098 ] {daa0b46b-c257-4f9e-9d91-ab4a89739ec0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.279106 [ 59098 ] {b7e5140e-8872-4b8f-b0ca-9dee13ce9c7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeLengthKm(NULL, NULL, NULL);) 2025.06.18 11:27:58.286453 [ 59098 ] {b7e5140e-8872-4b8f-b0ca-9dee13ce9c7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.332752 [ 59098 ] {b1814c35-11c3-415f-b136-dca39673efc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeLengthM(NULL, NULL, NULL);) 2025.06.18 11:27:58.337955 [ 59098 ] {b1814c35-11c3-415f-b136-dca39673efc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.377375 [ 59098 ] {70d3bad4-caea-4f64-b955-20d0106bdffa} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL);) 2025.06.18 11:27:58.382740 [ 59098 ] {70d3bad4-caea-4f64-b955-20d0106bdffa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.417054 [ 59098 ] {57d2a5fe-8b86-450f-b21a-066929647203} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL, NULL);) 2025.06.18 11:27:58.421453 [ 59098 ] {57d2a5fe-8b86-450f-b21a-066929647203} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.456759 [ 59098 ] {4d175773-f485-4bcd-9a50-6d37c519ced6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL);) 2025.06.18 11:27:58.460869 [ 59098 ] {4d175773-f485-4bcd-9a50-6d37c519ced6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.494948 [ 59098 ] {cefbf465-6687-46cb-a949-a04dec8db106} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetBaseCell(NULL, NULL, NULL);) 2025.06.18 11:27:58.501160 [ 59098 ] {cefbf465-6687-46cb-a949-a04dec8db106} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.541054 [ 59098 ] {1173222b-8741-4294-a902-fd24e3ad9bf7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.18 11:27:58.546798 [ 59098 ] {1173222b-8741-4294-a902-fd24e3ad9bf7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.584241 [ 59098 ] {92905882-9f25-4902-97f7-da6e36277e74} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetFaces(NULL, NULL, NULL);) 2025.06.18 11:27:58.590512 [ 59098 ] {92905882-9f25-4902-97f7-da6e36277e74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.627867 [ 59098 ] {91a51e45-f0f8-4ca8-9242-3bda1f09cd89} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.18 11:27:58.634698 [ 59098 ] {91a51e45-f0f8-4ca8-9242-3bda1f09cd89} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.673255 [ 59098 ] {b812d3de-5840-4eb9-9d87-6e379c0444f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.18 11:27:58.678327 [ 59098 ] {b812d3de-5840-4eb9-9d87-6e379c0444f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.718184 [ 59098 ] {cfdc19ca-bf24-46d7-9eb0-15bb54a13fc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetPentagonIndexes(NULL, NULL, NULL);) 2025.06.18 11:27:58.723970 [ 59098 ] {cfdc19ca-bf24-46d7-9eb0-15bb54a13fc6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.768975 [ 59098 ] {a06e0ad7-bf1e-4264-aa1e-4f344dcee61b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetRes0Indexes(NULL, NULL, NULL);) 2025.06.18 11:27:58.774654 [ 59098 ] {a06e0ad7-bf1e-4264-aa1e-4f344dcee61b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.817430 [ 59098 ] {5425e19a-d799-4b07-94c2-cb73449c1c8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetResolution(NULL, NULL, NULL);) 2025.06.18 11:27:58.822790 [ 59098 ] {5425e19a-d799-4b07-94c2-cb73449c1c8f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.868446 [ 59098 ] {56d91355-4d7c-41e0-99d9-250448629a43} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.18 11:27:58.874278 [ 59098 ] {56d91355-4d7c-41e0-99d9-250448629a43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.915432 [ 59098 ] {81dc1c44-5f8f-4904-a469-ef019affe28b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL);) 2025.06.18 11:27:58.921177 [ 59098 ] {81dc1c44-5f8f-4904-a469-ef019affe28b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:58.963483 [ 59098 ] {6b8ccb18-ceb7-4896-92d2-32ab02982072} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL);) 2025.06.18 11:27:58.969752 [ 59098 ] {6b8ccb18-ceb7-4896-92d2-32ab02982072} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.013898 [ 59098 ] {28350ffb-f8ec-424d-9c28-c11805267cba} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexAreaKm2(NULL, NULL, NULL);) 2025.06.18 11:27:59.018790 [ 59098 ] {28350ffb-f8ec-424d-9c28-c11805267cba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.056597 [ 59098 ] {e9cfdecc-e50c-4327-ab1d-ee97509df259} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexAreaM2(NULL, NULL, NULL);) 2025.06.18 11:27:59.061906 [ 59098 ] {e9cfdecc-e50c-4327-ab1d-ee97509df259} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.102496 [ 59098 ] {5872dfde-117b-4f46-a9eb-1f512afdb452} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexRing(NULL, NULL, NULL);) 2025.06.18 11:27:59.108196 [ 59098 ] {5872dfde-117b-4f46-a9eb-1f512afdb452} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.147681 [ 59098 ] {2034262c-7127-488a-937f-944aa8ac6f06} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IndexesAreNeighbors(NULL, NULL, NULL);) 2025.06.18 11:27:59.152816 [ 59098 ] {2034262c-7127-488a-937f-944aa8ac6f06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.189469 [ 59098 ] {698bd37d-64d4-48e3-925a-ad49874b31bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsPentagon(NULL, NULL, NULL);) 2025.06.18 11:27:59.194604 [ 59098 ] {698bd37d-64d4-48e3-925a-ad49874b31bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.232858 [ 59098 ] {f9047bf3-89a0-49d0-8f2c-f4a890864921} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsResClassIII(NULL, NULL, NULL);) 2025.06.18 11:27:59.238082 [ 59098 ] {f9047bf3-89a0-49d0-8f2c-f4a890864921} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.276533 [ 59098 ] {4ebc944b-e05f-411f-b9da-e716fd0ce6f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsValid(NULL, NULL, NULL);) 2025.06.18 11:27:59.281874 [ 59098 ] {4ebc944b-e05f-411f-b9da-e716fd0ce6f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.328097 [ 59098 ] {c5c1ac4c-546a-4b48-821a-bf90876cde18} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3Line(NULL, NULL, NULL);) 2025.06.18 11:27:59.333017 [ 59098 ] {c5c1ac4c-546a-4b48-821a-bf90876cde18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.374881 [ 59098 ] {3c63e2ce-f71c-4673-9e95-5646e432257a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3NumHexagons(NULL, NULL, NULL);) 2025.06.18 11:27:59.379758 [ 59098 ] {3c63e2ce-f71c-4673-9e95-5646e432257a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.414528 [ 59098 ] {36d9382b-f3d8-4667-b6c5-dbfc82d3b154} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistKm(NULL, NULL, NULL);) 2025.06.18 11:27:59.419215 [ 59098 ] {36d9382b-f3d8-4667-b6c5-dbfc82d3b154} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.456510 [ 59098 ] {ea0017b7-8d08-4a55-bfc1-8d6fb737d38b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistM(NULL, NULL, NULL);) 2025.06.18 11:27:59.462170 [ 59098 ] {ea0017b7-8d08-4a55-bfc1-8d6fb737d38b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.500017 [ 59098 ] {e5a4dcec-20bf-41f8-9a7c-08450ab91296} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistRads(NULL, NULL, NULL);) 2025.06.18 11:27:59.505484 [ 59098 ] {e5a4dcec-20bf-41f8-9a7c-08450ab91296} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.547255 [ 59098 ] {33c3130c-0c90-49be-8027-0caccae9e787} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToCenterChild(NULL, NULL, NULL);) 2025.06.18 11:27:59.552263 [ 59098 ] {33c3130c-0c90-49be-8027-0caccae9e787} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.587618 [ 59098 ] {6a4d1317-d5ba-45fa-b2dc-a05094ea6ec1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToChildren(NULL, NULL, NULL);) 2025.06.18 11:27:59.592371 [ 59098 ] {6a4d1317-d5ba-45fa-b2dc-a05094ea6ec1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.627093 [ 59098 ] {4fac112f-4d41-426b-bdcb-d66e4ddc8207} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToGeo(NULL, NULL, NULL);) 2025.06.18 11:27:59.632341 [ 59098 ] {4fac112f-4d41-426b-bdcb-d66e4ddc8207} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.673251 [ 59098 ] {d7754634-573e-41b3-8ccf-df2ea04ca65c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToGeoBoundary(NULL, NULL, NULL);) 2025.06.18 11:27:59.677977 [ 59098 ] {d7754634-573e-41b3-8ccf-df2ea04ca65c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.713028 [ 59098 ] {a912f70d-52d2-4ebf-a719-1429454fbf3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToParent(NULL, NULL, NULL);) 2025.06.18 11:27:59.717647 [ 59098 ] {a912f70d-52d2-4ebf-a719-1429454fbf3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.754501 [ 59098 ] {025370d2-a9a8-4ee7-bd94-6f1c9e55f069} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToString(NULL, NULL, NULL);) 2025.06.18 11:27:59.759352 [ 59098 ] {025370d2-a9a8-4ee7-bd94-6f1c9e55f069} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.796516 [ 59098 ] {8e94d5bb-8b5c-4b86-ab41-8e91c4b1081f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL);) 2025.06.18 11:27:59.801626 [ 59098 ] {8e94d5bb-8b5c-4b86-ab41-8e91c4b1081f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.838204 [ 59098 ] {0af0840e-0a83-4971-8fb9-0c25df33033b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3kRing(NULL, NULL, NULL);) 2025.06.18 11:27:59.842780 [ 59098 ] {0af0840e-0a83-4971-8fb9-0c25df33033b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.940460 [ 59098 ] {e98811a5-4ec1-48fb-8aed-165f111fcf07} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT has(NULL, NULL, NULL);) 2025.06.18 11:27:59.945197 [ 59098 ] {e98811a5-4ec1-48fb-8aed-165f111fcf07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:27:59.986437 [ 59098 ] {285cd0c9-0685-4153-a0ae-6be8db77efe6} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasAll(NULL, NULL, NULL);) 2025.06.18 11:27:59.991062 [ 59098 ] {285cd0c9-0685-4153-a0ae-6be8db77efe6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.025864 [ 59098 ] {57cd49c9-cdcd-470a-8b76-43f2b5733de3} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasAny(NULL, NULL, NULL);) 2025.06.18 11:28:00.030260 [ 59098 ] {57cd49c9-cdcd-470a-8b76-43f2b5733de3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.127703 [ 59098 ] {3f4bdc20-3585-4a04-b2fe-f0bc6527efa0} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequence(NULL, NULL, NULL);) 2025.06.18 11:28:00.132940 [ 59098 ] {3f4bdc20-3585-4a04-b2fe-f0bc6527efa0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.169943 [ 59098 ] {174b2e3b-a820-4b79-b2c0-324f905dc82e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:00.174811 [ 59098 ] {174b2e3b-a820-4b79-b2c0-324f905dc82e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.208456 [ 59098 ] {089a1469-5dc7-4da0-89fa-96951cf61181} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:00.212768 [ 59098 ] {089a1469-5dc7-4da0-89fa-96951cf61181} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.248104 [ 59098 ] {23052b32-ab99-4ae2-b501-d1ce5570f13a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:00.252956 [ 59098 ] {23052b32-ab99-4ae2-b501-d1ce5570f13a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.287638 [ 59098 ] {4ee3df6d-ace1-4b4a-beea-96b48db305aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubstr(NULL, NULL, NULL);) 2025.06.18 11:28:00.292370 [ 59098 ] {4ee3df6d-ace1-4b4a-beea-96b48db305aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.329215 [ 59098 ] {5518da79-f911-4f7f-8141-3a088ae01326} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasThreadFuzzer(NULL, NULL, NULL);) 2025.06.18 11:28:00.334087 [ 59098 ] {5518da79-f911-4f7f-8141-3a088ae01326} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.369733 [ 59098 ] {1c8ef3d3-49c3-4760-8fe2-4425f8ced258} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasToken(NULL, NULL, NULL);) 2025.06.18 11:28:00.374129 [ 59098 ] {1c8ef3d3-49c3-4760-8fe2-4425f8ced258} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.405982 [ 59098 ] {1981816d-34c0-4e55-a82f-a68d6a5d0125} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:00.409662 [ 59098 ] {1981816d-34c0-4e55-a82f-a68d6a5d0125} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.440672 [ 59098 ] {2514d0b3-6b61-4348-a9c9-d51843961fb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL);) 2025.06.18 11:28:00.444260 [ 59098 ] {2514d0b3-6b61-4348-a9c9-d51843961fb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.474379 [ 59098 ] {c56930db-e169-4a77-a865-05b2ed95af46} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenOrNull(NULL, NULL, NULL);) 2025.06.18 11:28:00.477818 [ 59098 ] {c56930db-e169-4a77-a865-05b2ed95af46} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.504531 [ 59098 ] {bde5e6be-b9c4-4972-a89d-6444d3ab8af2} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hex(NULL, NULL, NULL);) 2025.06.18 11:28:00.507485 [ 59098 ] {bde5e6be-b9c4-4972-a89d-6444d3ab8af2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.533991 [ 59098 ] {9d51a836-a713-4364-881a-ca1d6bbe0b55} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hilbertDecode(NULL, NULL, NULL);) 2025.06.18 11:28:00.537111 [ 59098 ] {9d51a836-a713-4364-881a-ca1d6bbe0b55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:00.977859 [ 59098 ] {3fbcfc32-c29a-4308-8870-929bd571d7f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hostName(NULL, NULL, NULL);) 2025.06.18 11:28:00.983012 [ 59098 ] {3fbcfc32-c29a-4308-8870-929bd571d7f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.017404 [ 59098 ] {847b443f-0ec7-4489-bfef-da52397eb08f} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hostname(NULL, NULL, NULL);) 2025.06.18 11:28:01.021866 [ 59098 ] {847b443f-0ec7-4489-bfef-da52397eb08f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.055975 [ 59098 ] {38061bfc-05d0-499b-a03a-b24a4a216d11} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hypot(NULL, NULL, NULL);) 2025.06.18 11:28:01.060802 [ 59098 ] {38061bfc-05d0-499b-a03a-b24a4a216d11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.095936 [ 59098 ] {08b47a08-b637-4caa-a2c0-716db3ee8474} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT identity(NULL, NULL, NULL);) 2025.06.18 11:28:01.100710 [ 59098 ] {08b47a08-b637-4caa-a2c0-716db3ee8474} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.133856 [ 59098 ] {fcca317c-8a6f-4fbe-bf16-1563839fd595} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT idnaDecode(NULL, NULL, NULL);) 2025.06.18 11:28:01.138295 [ 59098 ] {fcca317c-8a6f-4fbe-bf16-1563839fd595} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.171056 [ 59098 ] {6125298d-a83a-4554-9adb-4ade007d91e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT idnaEncode(NULL, NULL, NULL);) 2025.06.18 11:28:01.174947 [ 59098 ] {6125298d-a83a-4554-9adb-4ade007d91e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.281354 [ 59098 ] {e1c501e4-4f3b-471e-94df-83015e0b526e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ifNotFinite(NULL, NULL, NULL);) 2025.06.18 11:28:01.285514 [ 59098 ] {e1c501e4-4f3b-471e-94df-83015e0b526e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.314480 [ 59098 ] {b24ea37a-a7e8-4a1c-9744-34312c0c4b9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ifNull(NULL, NULL, NULL);) 2025.06.18 11:28:01.318382 [ 59098 ] {b24ea37a-a7e8-4a1c-9744-34312c0c4b9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.408175 [ 59098 ] {c1a9ddf7-b78f-43af-9959-76fa21166de9} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ilike(NULL, NULL, NULL);) 2025.06.18 11:28:01.412806 [ 59098 ] {c1a9ddf7-b78f-43af-9959-76fa21166de9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.440803 [ 59098 ] {5885ded1-8fdf-41ef-a779-1773e2629698} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT in(NULL, NULL, NULL);) 2025.06.18 11:28:01.445049 [ 59098 ] {5885ded1-8fdf-41ef-a779-1773e2629698} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.478058 [ 59098 ] {20d35d4b-b5e3-4a45-bdf0-e490a3317102} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT inIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:28:01.482304 [ 59098 ] {20d35d4b-b5e3-4a45-bdf0-e490a3317102} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.583666 [ 59098 ] {02a82b20-4d4f-4082-a174-5e56d25411b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT indexOf(NULL, NULL, NULL);) 2025.06.18 11:28:01.588498 [ 59098 ] {02a82b20-4d4f-4082-a174-5e56d25411b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.621318 [ 59098 ] {b5e5d55e-b401-49ab-8a6c-55f0c3d2d95a} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initcap(NULL, NULL, NULL);) 2025.06.18 11:28:01.625576 [ 59098 ] {b5e5d55e-b401-49ab-8a6c-55f0c3d2d95a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.658327 [ 59098 ] {9e932b56-0f7e-4d9a-b6dd-10b1d0b4abb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initcapUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:01.662646 [ 59098 ] {9e932b56-0f7e-4d9a-b6dd-10b1d0b4abb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.697300 [ 59098 ] {86790aa4-7fc2-41ed-9f6e-aa0185472bd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initialQueryID(NULL, NULL, NULL);) 2025.06.18 11:28:01.702094 [ 59098 ] {86790aa4-7fc2-41ed-9f6e-aa0185472bd4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.740944 [ 59098 ] {c8370f52-af36-4fe8-86a4-5c127be37977} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initial_query_id(NULL, NULL, NULL);) 2025.06.18 11:28:01.746101 [ 59098 ] {c8370f52-af36-4fe8-86a4-5c127be37977} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.786297 [ 59098 ] {9599e463-421e-49a5-afcf-070e134e4bb1} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initializeAggregation(NULL, NULL, NULL);) 2025.06.18 11:28:01.791883 [ 59098 ] {9599e463-421e-49a5-afcf-070e134e4bb1} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:01.902615 [ 59098 ] {3d47ccdc-8b9c-46ef-a06b-979ae2b415a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intDiv(NULL, NULL, NULL);) 2025.06.18 11:28:01.907841 [ 59098 ] {3d47ccdc-8b9c-46ef-a06b-979ae2b415a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.944931 [ 59098 ] {3037d8f6-7c84-46aa-9fd2-9a857a9dda8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intDivOrZero(NULL, NULL, NULL);) 2025.06.18 11:28:01.950806 [ 59098 ] {3037d8f6-7c84-46aa-9fd2-9a857a9dda8a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:01.991455 [ 59098 ] {0a4df6a1-190d-4581-b607-1f52e63377e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intExp10(NULL, NULL, NULL);) 2025.06.18 11:28:01.996205 [ 59098 ] {0a4df6a1-190d-4581-b607-1f52e63377e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.040538 [ 59098 ] {fdfdebdf-d8e4-4a70-b7f7-c0e666b71718} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intExp2(NULL, NULL, NULL);) 2025.06.18 11:28:02.048453 [ 59098 ] {fdfdebdf-d8e4-4a70-b7f7-c0e666b71718} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.090905 [ 59098 ] {717e34c4-30ca-42bc-9914-ebb3359a63fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intHash32(NULL, NULL, NULL);) 2025.06.18 11:28:02.098392 [ 59098 ] {717e34c4-30ca-42bc-9914-ebb3359a63fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.139191 [ 59098 ] {1d8d2777-4b0e-4fd5-b1df-1b2123535427} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intHash64(NULL, NULL, NULL);) 2025.06.18 11:28:02.144939 [ 59098 ] {1d8d2777-4b0e-4fd5-b1df-1b2123535427} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.283973 [ 59098 ] {768a5810-09cb-4f63-99f7-ddbb818eaccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isConstant(NULL, NULL, NULL);) 2025.06.18 11:28:02.289136 [ 59098 ] {768a5810-09cb-4f63-99f7-ddbb818eaccf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.398956 [ 59098 ] {9b26e9ec-0671-4fcd-a8db-2056e77ae7f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isDynamicElementInSharedData(NULL, NULL, NULL);) 2025.06.18 11:28:02.403995 [ 59098 ] {9b26e9ec-0671-4fcd-a8db-2056e77ae7f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.442589 [ 59098 ] {668828a8-65e4-4575-9fa6-7b33904fddab} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isFinite(NULL, NULL, NULL);) 2025.06.18 11:28:02.449479 [ 59098 ] {668828a8-65e4-4575-9fa6-7b33904fddab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.495661 [ 59098 ] {fca6506c-0b99-4e67-9fec-fbbfb2a97681} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPAddressInRange(NULL, NULL, NULL);) 2025.06.18 11:28:02.502283 [ 59098 ] {fca6506c-0b99-4e67-9fec-fbbfb2a97681} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.538357 [ 59098 ] {1d21ac9b-cf51-4448-8165-079e2ec94e38} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPv4String(NULL, NULL, NULL);) 2025.06.18 11:28:02.543710 [ 59098 ] {1d21ac9b-cf51-4448-8165-079e2ec94e38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.579838 [ 59098 ] {21d1389d-0297-4477-8621-926453d36378} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPv6String(NULL, NULL, NULL);) 2025.06.18 11:28:02.584883 [ 59098 ] {21d1389d-0297-4477-8621-926453d36378} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.623240 [ 59098 ] {b45e2253-89d7-4a4f-83cc-9e64992e0c9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isInfinite(NULL, NULL, NULL);) 2025.06.18 11:28:02.628024 [ 59098 ] {b45e2253-89d7-4a4f-83cc-9e64992e0c9e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.664262 [ 59098 ] {1cfb3532-472e-4c13-a891-36a474ad60d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNaN(NULL, NULL, NULL);) 2025.06.18 11:28:02.669577 [ 59098 ] {1cfb3532-472e-4c13-a891-36a474ad60d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.711302 [ 59098 ] {b6ed0e5d-f31d-4bcc-8711-fcfb3ee7f93c} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNotDistinctFrom(NULL, NULL, NULL);) 2025.06.18 11:28:02.716811 [ 59098 ] {b6ed0e5d-f31d-4bcc-8711-fcfb3ee7f93c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.755770 [ 59098 ] {94f38318-cd10-4af7-ab5e-e274e2f44abb} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNotNull(NULL, NULL, NULL);) 2025.06.18 11:28:02.760980 [ 59098 ] {94f38318-cd10-4af7-ab5e-e274e2f44abb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.797385 [ 59098 ] {50828bf2-7a4d-4e5c-af27-8a9f6e387939} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNull(NULL, NULL, NULL);) 2025.06.18 11:28:02.803033 [ 59098 ] {50828bf2-7a4d-4e5c-af27-8a9f6e387939} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.841945 [ 59098 ] {898077d4-1c09-48cb-bbc6-bb20e9fabc44} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNullable(NULL, NULL, NULL);) 2025.06.18 11:28:02.847160 [ 59098 ] {898077d4-1c09-48cb-bbc6-bb20e9fabc44} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.885610 [ 59098 ] {319f4872-6030-479e-bb6a-d590f754b5cc} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isValidJSON(NULL, NULL, NULL);) 2025.06.18 11:28:02.891094 [ 59098 ] {319f4872-6030-479e-bb6a-d590f754b5cc} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.931065 [ 59098 ] {642872d0-8c22-4e98-b1d7-e8302e13d045} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isValidUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:02.936370 [ 59098 ] {642872d0-8c22-4e98-b1d7-e8302e13d045} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:02.973707 [ 59098 ] {7c4cdcb1-61b2-42b6-ad2d-e8196c0d524f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isZeroOrNull(NULL, NULL, NULL);) 2025.06.18 11:28:02.978812 [ 59098 ] {7c4cdcb1-61b2-42b6-ad2d-e8196c0d524f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:03.015600 [ 59098 ] {77478b20-7f8b-4c67-b6ad-f9e3d33a7b15} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jaroSimilarity(NULL, NULL, NULL);) 2025.06.18 11:28:03.020270 [ 59098 ] {77478b20-7f8b-4c67-b6ad-f9e3d33a7b15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:03.053527 [ 59098 ] {79d0adb7-1f5d-45aa-80da-8682d0570104} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jaroWinklerSimilarity(NULL, NULL, NULL);) 2025.06.18 11:28:03.057778 [ 59098 ] {79d0adb7-1f5d-45aa-80da-8682d0570104} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:03.231572 [ 59098 ] {2df746ff-bbc6-4883-b43a-8f4703a1acb8} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT joinGet(NULL, NULL, NULL);) 2025.06.18 11:28:03.237512 [ 59098 ] {2df746ff-bbc6-4883-b43a-8f4703a1acb8} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:03.276762 [ 59098 ] {21770c06-fc0d-4985-82d9-ae595f626a61} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT joinGetOrNull(NULL, NULL, NULL);) 2025.06.18 11:28:03.282123 [ 59098 ] {21770c06-fc0d-4985-82d9-ae595f626a61} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:03.391996 [ 59098 ] {a6f14ec4-c3d3-4075-abe9-be1b34a62e48} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jumpConsistentHash(NULL, NULL, NULL);) 2025.06.18 11:28:03.396996 [ 59098 ] {a6f14ec4-c3d3-4075-abe9-be1b34a62e48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:03.616181 [ 59098 ] {c52b3ec2-a307-4a91-89f9-37740178ce28} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT kostikConsistentHash(NULL, NULL, NULL);) 2025.06.18 11:28:03.622547 [ 59098 ] {c52b3ec2-a307-4a91-89f9-37740178ce28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:04.025852 [ 59098 ] {f43d0052-ac97-4ab0-aa96-15994de4c26a} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lagInFrame(NULL, NULL, NULL);) 2025.06.18 11:28:04.031915 [ 59098 ] {f43d0052-ac97-4ab0-aa96-15994de4c26a} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.18 11:28:04.315630 [ 59098 ] {8d51d73a-194e-4d9a-b905-9777e830ed9f} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT last_value_respect_nulls(NULL, NULL, NULL);) 2025.06.18 11:28:04.322294 [ 59098 ] {8d51d73a-194e-4d9a-b905-9777e830ed9f} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:04.359491 [ 59098 ] {713d50a8-12d4-4808-9518-96d6be96bc78} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lcase(NULL, NULL, NULL);) 2025.06.18 11:28:04.366006 [ 59098 ] {713d50a8-12d4-4808-9518-96d6be96bc78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:04.425870 [ 59098 ] {e7fb43e1-b4b0-43f6-9ddb-bdc3b4507130} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lcm(NULL, NULL, NULL);) 2025.06.18 11:28:04.434252 [ 59098 ] {e7fb43e1-b4b0-43f6-9ddb-bdc3b4507130} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:04.473714 [ 59098 ] {983dd955-db31-4ac5-a514-abd32e821179} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT leadInFrame(NULL, NULL, NULL);) 2025.06.18 11:28:04.479192 [ 59098 ] {983dd955-db31-4ac5-a514-abd32e821179} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.18 11:28:04.617557 [ 59098 ] {9ba209b9-ac6a-4278-aa21-d3eb7888836c} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT left(NULL, NULL, NULL);) 2025.06.18 11:28:04.623464 [ 59098 ] {9ba209b9-ac6a-4278-aa21-d3eb7888836c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:04.832136 [ 59098 ] {ba4d4b6e-1e61-4107-9d53-0568056d4f16} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT leftUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:04.837338 [ 59098 ] {ba4d4b6e-1e61-4107-9d53-0568056d4f16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:04.885638 [ 59098 ] {fe8f2eec-6017-474c-9802-813521ca3a28} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lemmatize(NULL, NULL, NULL);) 2025.06.18 11:28:04.896587 [ 59098 ] {fe8f2eec-6017-474c-9802-813521ca3a28} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:28:04.961980 [ 59098 ] {5c80cecb-1f30-4049-b32f-52ca72f57380} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT length(NULL, NULL, NULL);) 2025.06.18 11:28:04.967098 [ 59098 ] {5c80cecb-1f30-4049-b32f-52ca72f57380} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.003000 [ 59098 ] {582f260c-9cf8-4ebf-a50b-60793c47f922} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lengthUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:05.007761 [ 59098 ] {582f260c-9cf8-4ebf-a50b-60793c47f922} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.043827 [ 59098 ] {72d30ace-afe7-4179-ae1a-0b77104c80b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT less(NULL, NULL, NULL);) 2025.06.18 11:28:05.049028 [ 59098 ] {72d30ace-afe7-4179-ae1a-0b77104c80b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.084697 [ 59098 ] {79a3f185-39f0-4f42-bf06-4e1081e08fcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lessOrEquals(NULL, NULL, NULL);) 2025.06.18 11:28:05.090240 [ 59098 ] {79a3f185-39f0-4f42-bf06-4e1081e08fcc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.126347 [ 59098 ] {86448163-dd89-4421-a3f3-1f4e64b9bc65} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT levenshteinDistance(NULL, NULL, NULL);) 2025.06.18 11:28:05.130914 [ 59098 ] {86448163-dd89-4421-a3f3-1f4e64b9bc65} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.161697 [ 59098 ] {a3f45c9e-d62b-44f8-8bf6-15b0e860dbf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT levenshteinDistanceUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:05.165786 [ 59098 ] {a3f45c9e-d62b-44f8-8bf6-15b0e860dbf1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.198991 [ 59098 ] {c99366c9-082c-4d97-adb5-758536921cf0} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lgamma(NULL, NULL, NULL);) 2025.06.18 11:28:05.203420 [ 59098 ] {c99366c9-082c-4d97-adb5-758536921cf0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.236667 [ 59098 ] {4720e4ca-89e3-49eb-81d5-08902182ff4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT like(NULL, NULL, NULL);) 2025.06.18 11:28:05.240753 [ 59098 ] {4720e4ca-89e3-49eb-81d5-08902182ff4d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.269129 [ 59098 ] {25740aa6-5816-496e-ac7e-a4ca94371fbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ln(NULL, NULL, NULL);) 2025.06.18 11:28:05.272855 [ 59098 ] {25740aa6-5816-496e-ac7e-a4ca94371fbb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.371306 [ 59098 ] {e5741483-7345-40d8-8fc8-b14734801aae} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log(NULL, NULL, NULL);) 2025.06.18 11:28:05.376083 [ 59098 ] {e5741483-7345-40d8-8fc8-b14734801aae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.406926 [ 59098 ] {5119d9c6-09f8-4c2f-9891-92114472aa4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log10(NULL, NULL, NULL);) 2025.06.18 11:28:05.410755 [ 59098 ] {5119d9c6-09f8-4c2f-9891-92114472aa4c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.439965 [ 59098 ] {e1a80480-586c-41c6-84c6-f8e38caaf876} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log1p(NULL, NULL, NULL);) 2025.06.18 11:28:05.444985 [ 59098 ] {e1a80480-586c-41c6-84c6-f8e38caaf876} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.478471 [ 59098 ] {53935500-9696-4ace-af95-3bb5f2dcd229} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log2(NULL, NULL, NULL);) 2025.06.18 11:28:05.483775 [ 59098 ] {53935500-9696-4ace-af95-3bb5f2dcd229} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.519709 [ 59098 ] {89952887-1839-44e0-b6ad-f324b268a6d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT logTrace(NULL, NULL, NULL);) 2025.06.18 11:28:05.524898 [ 59098 ] {89952887-1839-44e0-b6ad-f324b268a6d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.569676 [ 59098 ] {1770ed3b-2c78-4fb3-ad9f-97453455f79e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowCardinalityIndices(NULL, NULL, NULL);) 2025.06.18 11:28:05.576790 [ 59098 ] {1770ed3b-2c78-4fb3-ad9f-97453455f79e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.615503 [ 59098 ] {dc1b868a-d5dd-4f76-a4d0-8e47e16ed232} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowCardinalityKeys(NULL, NULL, NULL);) 2025.06.18 11:28:05.620526 [ 59098 ] {dc1b868a-d5dd-4f76-a4d0-8e47e16ed232} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.656862 [ 59098 ] {d0368500-99a0-4aad-85c6-c42957870238} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lower(NULL, NULL, NULL);) 2025.06.18 11:28:05.662302 [ 59098 ] {d0368500-99a0-4aad-85c6-c42957870238} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:05.701140 [ 59098 ] {550f7607-a083-404b-a432-1af36449f498} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowerUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:05.706422 [ 59098 ] {550f7607-a083-404b-a432-1af36449f498} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:06.374226 [ 59098 ] {7fbd4bb5-b0fd-4c95-8b95-3f92b4544c6a} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT map(NULL, NULL, NULL);) 2025.06.18 11:28:06.382529 [ 59098 ] {7fbd4bb5-b0fd-4c95-8b95-3f92b4544c6a} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:06.700197 [ 59098 ] {83dc176a-add5-45f2-9b9e-a655d093e073} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapContains(NULL, NULL, NULL);) 2025.06.18 11:28:06.704791 [ 59098 ] {83dc176a-add5-45f2-9b9e-a655d093e073} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:07.038141 [ 59098 ] {c0f12a7e-ac4a-4c61-b175-0d39f5cab747} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapFromArrays(NULL, NULL, NULL);) 2025.06.18 11:28:07.043797 [ 59098 ] {c0f12a7e-ac4a-4c61-b175-0d39f5cab747} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:07.163183 [ 59098 ] {b05ab082-d0ea-4f00-bb23-30bd4375c325} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapKeys(NULL, NULL, NULL);) 2025.06.18 11:28:07.168318 [ 59098 ] {b05ab082-d0ea-4f00-bb23-30bd4375c325} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:07.648656 [ 59098 ] {be6c78f7-cc38-4450-879a-cc3c753c1e1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapUpdate(NULL, NULL, NULL);) 2025.06.18 11:28:07.653768 [ 59098 ] {be6c78f7-cc38-4450-879a-cc3c753c1e1f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:07.688909 [ 59098 ] {fdc493c5-d749-4ad4-b0e0-da4912f1bccd} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapValues(NULL, NULL, NULL);) 2025.06.18 11:28:07.695457 [ 59098 ] {fdc493c5-d749-4ad4-b0e0-da4912f1bccd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:07.747633 [ 59098 ] {6e06ef34-246f-49a9-8c33-e956f3840873} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT match(NULL, NULL, NULL);) 2025.06.18 11:28:07.754079 [ 59098 ] {6e06ef34-246f-49a9-8c33-e956f3840873} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:07.812166 [ 59098 ] {60249bae-2c39-4790-9b4d-838400ca3c90} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT materialize(NULL, NULL, NULL);) 2025.06.18 11:28:07.817283 [ 59098 ] {60249bae-2c39-4790-9b4d-838400ca3c90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:07.970858 [ 59098 ] {983794ec-f894-48fc-81c3-d7daaf0d44d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT max2(NULL, NULL, NULL);) 2025.06.18 11:28:07.975747 [ 59098 ] {983794ec-f894-48fc-81c3-d7daaf0d44d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.141881 [ 59098 ] {81922b0a-182b-4cac-aeb5-71daed714fbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT min2(NULL, NULL, NULL);) 2025.06.18 11:28:10.147323 [ 59098 ] {81922b0a-182b-4cac-aeb5-71daed714fbf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.275244 [ 59098 ] {ed7fc216-23e4-4861-80fe-456f71493b8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeContinous(NULL, NULL, NULL);) 2025.06.18 11:28:10.280417 [ 59098 ] {ed7fc216-23e4-4861-80fe-456f71493b8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.320485 [ 59098 ] {67f9ae51-6d8c-44e4-9809-aa529ff29a43} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeContinuous(NULL, NULL, NULL);) 2025.06.18 11:28:10.326294 [ 59098 ] {67f9ae51-6d8c-44e4-9809-aa529ff29a43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.367538 [ 59098 ] {847d3739-5fe7-4080-90a7-5d29ed9e6cce} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeConversion(NULL, NULL, NULL);) 2025.06.18 11:28:10.373568 [ 59098 ] {847d3739-5fe7-4080-90a7-5d29ed9e6cce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.410009 [ 59098 ] {f43f1e8d-f79d-4e3d-bfc4-759878ec49f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minus(NULL, NULL, NULL);) 2025.06.18 11:28:10.415317 [ 59098 ] {f43f1e8d-f79d-4e3d-bfc4-759878ec49f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.452666 [ 59098 ] {99c93d06-21c5-4477-b4f2-d85b983504f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mismatches(NULL, NULL, NULL);) 2025.06.18 11:28:10.457696 [ 59098 ] {99c93d06-21c5-4477-b4f2-d85b983504f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.498504 [ 59098 ] {c6c62357-d712-4643-be76-ba4c7ae89a5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mod(NULL, NULL, NULL);) 2025.06.18 11:28:10.504339 [ 59098 ] {c6c62357-d712-4643-be76-ba4c7ae89a5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.549222 [ 59098 ] {fdce2290-6801-4d45-9dd2-2b262e17a70e} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT modulo(NULL, NULL, NULL);) 2025.06.18 11:28:10.555784 [ 59098 ] {fdce2290-6801-4d45-9dd2-2b262e17a70e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.601172 [ 59098 ] {71de9685-5141-4d49-a175-a46b9e4f19f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT moduloLegacy(NULL, NULL, NULL);) 2025.06.18 11:28:10.607366 [ 59098 ] {71de9685-5141-4d49-a175-a46b9e4f19f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.645938 [ 59098 ] {4d06b028-4f5e-4b69-a197-e3ac05b459a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT moduloOrZero(NULL, NULL, NULL);) 2025.06.18 11:28:10.651850 [ 59098 ] {4d06b028-4f5e-4b69-a197-e3ac05b459a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.697439 [ 59098 ] {07a6a9d6-ed5c-4f97-9fba-c0a3fc9d3305} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT monthName(NULL, NULL, NULL);) 2025.06.18 11:28:10.703470 [ 59098 ] {07a6a9d6-ed5c-4f97-9fba-c0a3fc9d3305} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:10.745448 [ 59098 ] {27b26eb5-2c2d-4689-9a13-3e691391f905} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mortonDecode(NULL, NULL, NULL);) 2025.06.18 11:28:10.751129 [ 59098 ] {27b26eb5-2c2d-4689-9a13-3e691391f905} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.195535 [ 59098 ] {835e3430-96bc-463e-8908-5dbf064d19b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAllIndices(NULL, NULL, NULL);) 2025.06.18 11:28:11.201816 [ 59098 ] {835e3430-96bc-463e-8908-5dbf064d19b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.243501 [ 59098 ] {877e8693-6b87-4d18-8a45-49768e6111cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAny(NULL, NULL, NULL);) 2025.06.18 11:28:11.248027 [ 59098 ] {877e8693-6b87-4d18-8a45-49768e6111cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.282841 [ 59098 ] {0d5cc743-5d83-4399-a5b7-ebb2e806f0ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAnyIndex(NULL, NULL, NULL);) 2025.06.18 11:28:11.287617 [ 59098 ] {0d5cc743-5d83-4399-a5b7-ebb2e806f0ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.326093 [ 59098 ] {bb06488a-dac7-4a4d-a048-f4140f6ba4c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositions(NULL, NULL, NULL);) 2025.06.18 11:28:11.331404 [ 59098 ] {bb06488a-dac7-4a4d-a048-f4140f6ba4c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.365543 [ 59098 ] {0563ebf3-96cd-479d-84d2-18ebbbded727} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:11.370313 [ 59098 ] {0563ebf3-96cd-479d-84d2-18ebbbded727} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.405170 [ 59098 ] {ee99edc4-11c2-421c-9b0b-01c3133a42bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:11.410137 [ 59098 ] {ee99edc4-11c2-421c-9b0b-01c3133a42bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.447269 [ 59098 ] {ee69205a-4f92-43e7-9a72-f865c36b7816} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:11.452657 [ 59098 ] {ee69205a-4f92-43e7-9a72-f865c36b7816} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.488850 [ 59098 ] {1f2e2c1d-3e8a-4d83-a9ea-d934ed8782ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAny(NULL, NULL, NULL);) 2025.06.18 11:28:11.494399 [ 59098 ] {1f2e2c1d-3e8a-4d83-a9ea-d934ed8782ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.547373 [ 59098 ] {b1280551-8fcb-4543-9db9-e65bfdc7bb88} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:11.554989 [ 59098 ] {b1280551-8fcb-4543-9db9-e65bfdc7bb88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.593914 [ 59098 ] {3c12477c-f39d-465d-b2cb-6d4311c793ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:11.600465 [ 59098 ] {3c12477c-f39d-465d-b2cb-6d4311c793ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.637960 [ 59098 ] {b0ecbb6f-1b5e-4f73-b196-dffeb396528b} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:11.644111 [ 59098 ] {b0ecbb6f-1b5e-4f73-b196-dffeb396528b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.682454 [ 59098 ] {d50aaac0-9656-4403-a479-59780f6f53a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndex(NULL, NULL, NULL);) 2025.06.18 11:28:11.691241 [ 59098 ] {d50aaac0-9656-4403-a479-59780f6f53a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.763391 [ 59098 ] {beb729ce-9e41-4be7-baf1-863bae902cf6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:11.768797 [ 59098 ] {beb729ce-9e41-4be7-baf1-863bae902cf6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.807386 [ 59098 ] {3c333c23-c6e4-4a8b-8416-64e120affaed} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:11.812150 [ 59098 ] {3c333c23-c6e4-4a8b-8416-64e120affaed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.847529 [ 59098 ] {95c3460f-aa8e-48aa-9d2e-756caf67bfd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:11.852302 [ 59098 ] {95c3460f-aa8e-48aa-9d2e-756caf67bfd3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.919058 [ 59098 ] {73c3d7c8-0ac5-4058-a236-9eab130246a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPosition(NULL, NULL, NULL);) 2025.06.18 11:28:11.925878 [ 59098 ] {73c3d7c8-0ac5-4058-a236-9eab130246a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:11.965718 [ 59098 ] {96cafd1c-afcf-4ef3-bf14-8ebded21017f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:11.970699 [ 59098 ] {96cafd1c-afcf-4ef3-bf14-8ebded21017f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.007052 [ 59098 ] {a07b01d0-1170-4927-8713-c58ac8d43d38} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:12.012124 [ 59098 ] {a07b01d0-1170-4927-8713-c58ac8d43d38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.052263 [ 59098 ] {d25fbd1d-b9ed-421f-82e2-538ee1fd58c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:12.059809 [ 59098 ] {d25fbd1d-b9ed-421f-82e2-538ee1fd58c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.113999 [ 59098 ] {0ad91f13-2840-4c7c-b7be-a3f1395bd914} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiply(NULL, NULL, NULL);) 2025.06.18 11:28:12.120447 [ 59098 ] {0ad91f13-2840-4c7c-b7be-a3f1395bd914} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.580685 [ 59098 ] {d597c961-ac2f-4745-b7ae-fa8ae3631256} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT negate(NULL, NULL, NULL);) 2025.06.18 11:28:12.585692 [ 59098 ] {d597c961-ac2f-4745-b7ae-fa8ae3631256} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.619652 [ 59098 ] {447118a3-5f9a-4197-a6cc-ae552b3fe772} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT neighbor(NULL, NULL, NULL);) 2025.06.18 11:28:12.624730 [ 59098 ] {447118a3-5f9a-4197-a6cc-ae552b3fe772} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:28:12.729219 [ 59098 ] {ea5cd6e6-adc5-4167-9ccd-163cec187e94} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT netloc(NULL, NULL, NULL);) 2025.06.18 11:28:12.733953 [ 59098 ] {ea5cd6e6-adc5-4167-9ccd-163cec187e94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.767798 [ 59098 ] {42c78a6b-f4de-4eb7-a5d0-c547cd500ac2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistance(NULL, NULL, NULL);) 2025.06.18 11:28:12.772778 [ 59098 ] {42c78a6b-f4de-4eb7-a5d0-c547cd500ac2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.809449 [ 59098 ] {aa919c6a-d7a1-436e-a53f-29c66165dc5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:12.814181 [ 59098 ] {aa919c6a-d7a1-436e-a53f-29c66165dc5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.851590 [ 59098 ] {e68de60e-2778-489e-8c74-6011b3108021} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:12.857116 [ 59098 ] {e68de60e-2778-489e-8c74-6011b3108021} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:12.893403 [ 59098 ] {35880e8d-da3f-4f07-9104-323dc9a01e32} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:12.898802 [ 59098 ] {35880e8d-da3f-4f07-9104-323dc9a01e32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:13.558624 [ 59098 ] {6f8a313e-d0b1-4bdb-9dd4-79e2912bac47} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearch(NULL, NULL, NULL);) 2025.06.18 11:28:13.564335 [ 59098 ] {6f8a313e-d0b1-4bdb-9dd4-79e2912bac47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:13.603936 [ 59098 ] {c85b5a20-3c27-4968-acac-479d924e3eeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL);) 2025.06.18 11:28:13.609068 [ 59098 ] {c85b5a20-3c27-4968-acac-479d924e3eeb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:13.644665 [ 59098 ] {f22c012a-d24f-4cd1-b801-26b29dd4410d} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:13.650393 [ 59098 ] {f22c012a-d24f-4cd1-b801-26b29dd4410d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:13.686162 [ 59098 ] {7289b5ab-b6e3-4713-96c1-86f987881eee} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:13.691737 [ 59098 ] {7289b5ab-b6e3-4713-96c1-86f987881eee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.033667 [ 59098 ] {47f91e1a-b86b-423d-aae0-3e23355dd196} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngrams(NULL, NULL, NULL);) 2025.06.18 11:28:14.040334 [ 59098 ] {47f91e1a-b86b-423d-aae0-3e23355dd196} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.078138 [ 59098 ] {26c97098-b7eb-4a76-b6a2-f66574e243af} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nonNegativeDerivative(NULL, NULL, NULL);) 2025.06.18 11:28:14.083545 [ 59098 ] {26c97098-b7eb-4a76-b6a2-f66574e243af} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.18 11:28:14.122917 [ 59098 ] {b539eae3-e0c9-463c-a41e-5875d9f28dc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL1(NULL, NULL, NULL);) 2025.06.18 11:28:14.128337 [ 59098 ] {b539eae3-e0c9-463c-a41e-5875d9f28dc1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.166648 [ 59098 ] {792ed171-342a-404e-81f8-d087ac5e26dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL2(NULL, NULL, NULL);) 2025.06.18 11:28:14.172397 [ 59098 ] {792ed171-342a-404e-81f8-d087ac5e26dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.209584 [ 59098 ] {d286ddbc-2ade-4d6b-85ec-817a27a32610} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL2Squared(NULL, NULL, NULL);) 2025.06.18 11:28:14.215509 [ 59098 ] {d286ddbc-2ade-4d6b-85ec-817a27a32610} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.261665 [ 59098 ] {a4901793-ac78-4b84-ad7a-fdfdfe755623} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normLinf(NULL, NULL, NULL);) 2025.06.18 11:28:14.270197 [ 59098 ] {a4901793-ac78-4b84-ad7a-fdfdfe755623} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.322325 [ 59098 ] {3761b0c5-06c1-4639-874b-189227ed96e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normLp(NULL, NULL, NULL);) 2025.06.18 11:28:14.327619 [ 59098 ] {3761b0c5-06c1-4639-874b-189227ed96e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.362495 [ 59098 ] {4642762b-b941-443f-a0f5-2681dd92cfe0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeL1(NULL, NULL, NULL);) 2025.06.18 11:28:14.367756 [ 59098 ] {4642762b-b941-443f-a0f5-2681dd92cfe0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.403253 [ 59098 ] {742f38bd-0057-439b-9887-34049e1bfc39} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeL2(NULL, NULL, NULL);) 2025.06.18 11:28:14.408059 [ 59098 ] {742f38bd-0057-439b-9887-34049e1bfc39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.445297 [ 59098 ] {bd76729f-3ff6-4258-be82-51085e05ac22} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeLinf(NULL, NULL, NULL);) 2025.06.18 11:28:14.450628 [ 59098 ] {bd76729f-3ff6-4258-be82-51085e05ac22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.489118 [ 59098 ] {a407ecdc-cb48-421e-8645-51acc32e0cfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeLp(NULL, NULL, NULL);) 2025.06.18 11:28:14.494831 [ 59098 ] {a407ecdc-cb48-421e-8645-51acc32e0cfc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.537899 [ 59098 ] {af80df0a-bf7f-4551-91d6-b9bedbeed6dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeQuery(NULL, NULL, NULL);) 2025.06.18 11:28:14.544368 [ 59098 ] {af80df0a-bf7f-4551-91d6-b9bedbeed6dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.582662 [ 59098 ] {e479c14a-cc6c-4aca-8d38-8946703cc43d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeQueryKeepNames(NULL, NULL, NULL);) 2025.06.18 11:28:14.587930 [ 59098 ] {e479c14a-cc6c-4aca-8d38-8946703cc43d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.623653 [ 59098 ] {6d448dcb-b51f-403a-a7b7-be6f614c315f} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFC(NULL, NULL, NULL);) 2025.06.18 11:28:14.628599 [ 59098 ] {6d448dcb-b51f-403a-a7b7-be6f614c315f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.662398 [ 59098 ] {bbef6942-5395-453b-b02c-c273695f37d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFD(NULL, NULL, NULL);) 2025.06.18 11:28:14.668097 [ 59098 ] {bbef6942-5395-453b-b02c-c273695f37d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.709249 [ 59098 ] {aaf5dc04-a101-4ff3-bc39-594fdc829961} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFKC(NULL, NULL, NULL);) 2025.06.18 11:28:14.715714 [ 59098 ] {aaf5dc04-a101-4ff3-bc39-594fdc829961} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.751003 [ 59098 ] {1889a465-d18a-4589-98fa-892fe5cc70d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFKD(NULL, NULL, NULL);) 2025.06.18 11:28:14.755811 [ 59098 ] {1889a465-d18a-4589-98fa-892fe5cc70d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.791286 [ 59098 ] {496338f7-0731-4bd0-b874-4a06c7d43827} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizedQueryHash(NULL, NULL, NULL);) 2025.06.18 11:28:14.795892 [ 59098 ] {496338f7-0731-4bd0-b874-4a06c7d43827} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.833586 [ 59098 ] {e6829ef5-5b9c-412c-be6d-eda2776d032b} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL);) 2025.06.18 11:28:14.838885 [ 59098 ] {e6829ef5-5b9c-412c-be6d-eda2776d032b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.875604 [ 59098 ] {654bc902-6a23-471a-b567-3a3d2e4c8043} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT not(NULL, NULL, NULL);) 2025.06.18 11:28:14.880879 [ 59098 ] {654bc902-6a23-471a-b567-3a3d2e4c8043} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.926601 [ 59098 ] {8bc31978-dfe9-4f5a-9e21-8b731f49a103} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notEmpty(NULL, NULL, NULL);) 2025.06.18 11:28:14.931784 [ 59098 ] {8bc31978-dfe9-4f5a-9e21-8b731f49a103} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:14.968932 [ 59098 ] {56ebf65f-3754-40ce-b367-d8e3897c1e4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notEquals(NULL, NULL, NULL);) 2025.06.18 11:28:14.973805 [ 59098 ] {56ebf65f-3754-40ce-b367-d8e3897c1e4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.005814 [ 59098 ] {7b0dbe27-232d-4571-8d82-72a9f60d7ab2} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notILike(NULL, NULL, NULL);) 2025.06.18 11:28:15.014635 [ 59098 ] {7b0dbe27-232d-4571-8d82-72a9f60d7ab2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.047038 [ 59098 ] {8718dd1a-1cdb-4482-867b-9b916ae354b7} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notIn(NULL, NULL, NULL);) 2025.06.18 11:28:15.051528 [ 59098 ] {8718dd1a-1cdb-4482-867b-9b916ae354b7} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.088154 [ 59098 ] {98596235-cc46-4415-9c32-573d38fba364} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notInIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:28:15.094806 [ 59098 ] {98596235-cc46-4415-9c32-573d38fba364} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.131348 [ 59098 ] {82d21c6a-0631-4872-9220-3cdc48ea532f} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notLike(NULL, NULL, NULL);) 2025.06.18 11:28:15.136412 [ 59098 ] {82d21c6a-0631-4872-9220-3cdc48ea532f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.173201 [ 59098 ] {d59a122a-8746-431b-af25-7078e23f7b34} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notNullIn(NULL, NULL, NULL);) 2025.06.18 11:28:15.178972 [ 59098 ] {d59a122a-8746-431b-af25-7078e23f7b34} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.212388 [ 59098 ] {e788e642-0983-4e7d-889d-9fc6868c3254} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notNullInIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:28:15.217519 [ 59098 ] {e788e642-0983-4e7d-889d-9fc6868c3254} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.511071 [ 59098 ] {b9d5d62b-c1b5-412b-9871-884ca31d41b9} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT now(NULL, NULL, NULL);) 2025.06.18 11:28:15.516386 [ 59098 ] {b9d5d62b-c1b5-412b-9871-884ca31d41b9} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.688490 [ 59098 ] {59395fb1-784f-4d39-852b-436f76ab9231} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nth_value(NULL, NULL, NULL);) 2025.06.18 11:28:15.693293 [ 59098 ] {59395fb1-784f-4d39-852b-436f76ab9231} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.731308 [ 59098 ] {cf946965-5119-49cb-aa20-bd5ef80db024} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ntile(NULL, NULL, NULL);) 2025.06.18 11:28:15.737073 [ 59098 ] {cf946965-5119-49cb-aa20-bd5ef80db024} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.778596 [ 59098 ] {29962eeb-8e1a-48eb-80cf-692abbe34104} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullIf(NULL, NULL, NULL);) 2025.06.18 11:28:15.783638 [ 59098 ] {29962eeb-8e1a-48eb-80cf-692abbe34104} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.823754 [ 59098 ] {15c4f277-d81a-43a7-ad6a-a84a212344ec} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullIn(NULL, NULL, NULL);) 2025.06.18 11:28:15.830515 [ 59098 ] {15c4f277-d81a-43a7-ad6a-a84a212344ec} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:15.869065 [ 59098 ] {7a03f6ec-24c4-4d1e-bbd3-74c1ee517b1d} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullInIgnoreSet(NULL, NULL, NULL);) 2025.06.18 11:28:15.875661 [ 59098 ] {7a03f6ec-24c4-4d1e-bbd3-74c1ee517b1d} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:17.469275 [ 59098 ] {6f1d9c09-5315-417d-aa22-ad7d1fce7c46} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSize(NULL, NULL, NULL);) 2025.06.18 11:28:17.474011 [ 59098 ] {6f1d9c09-5315-417d-aa22-ad7d1fce7c46} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:17.507586 [ 59098 ] {3b24887d-f695-4bb1-bba9-452527e39bf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSizeOrNull(NULL, NULL, NULL);) 2025.06.18 11:28:17.512345 [ 59098 ] {3b24887d-f695-4bb1-bba9-452527e39bf3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:17.546358 [ 59098 ] {b40ae151-5895-4d02-9cfc-02bac986dc21} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSizeOrZero(NULL, NULL, NULL);) 2025.06.18 11:28:17.551690 [ 59098 ] {b40ae151-5895-4d02-9cfc-02bac986dc21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:17.786347 [ 59098 ] {636faa8d-2e5f-4b9a-8c37-b06e3dff9f81} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT path(NULL, NULL, NULL);) 2025.06.18 11:28:17.791479 [ 59098 ] {636faa8d-2e5f-4b9a-8c37-b06e3dff9f81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:17.829045 [ 59098 ] {fe2fc4b1-2d39-4acb-bb4a-108f94d40548} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pathFull(NULL, NULL, NULL);) 2025.06.18 11:28:17.834118 [ 59098 ] {fe2fc4b1-2d39-4acb-bb4a-108f94d40548} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:17.904824 [ 59098 ] {c3ac2e86-5766-4aa8-bebc-98b15fff551c} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT percentRank(NULL, NULL, NULL);) 2025.06.18 11:28:17.912235 [ 59098 ] {c3ac2e86-5766-4aa8-bebc-98b15fff551c} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:28:17.995690 [ 59098 ] {ca104d41-760f-4051-81d8-38922ea68323} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT percent_rank(NULL, NULL, NULL);) 2025.06.18 11:28:18.004957 [ 59098 ] {ca104d41-760f-4051-81d8-38922ea68323} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:28:18.044157 [ 59098 ] {19957c15-3fd1-402f-a3e9-03dd3c5025bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pi(NULL, NULL, NULL);) 2025.06.18 11:28:18.049764 [ 59098 ] {19957c15-3fd1-402f-a3e9-03dd3c5025bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.085332 [ 59098 ] {63644030-a5cb-458d-a60a-87d189ede142} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT plus(NULL, NULL, NULL);) 2025.06.18 11:28:18.090414 [ 59098 ] {63644030-a5cb-458d-a60a-87d189ede142} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.136650 [ 59098 ] {c45cc555-28cc-4921-a210-3ce348d843c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pmod(NULL, NULL, NULL);) 2025.06.18 11:28:18.144495 [ 59098 ] {c45cc555-28cc-4921-a210-3ce348d843c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.353727 [ 59098 ] {b49e2217-efc8-459d-88f9-8b12e9869307} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonAreaCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.360231 [ 59098 ] {b49e2217-efc8-459d-88f9-8b12e9869307} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.396757 [ 59098 ] {a73aa06d-6ee1-49ae-9087-63e60d8c5fcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonAreaSpherical(NULL, NULL, NULL);) 2025.06.18 11:28:18.402294 [ 59098 ] {a73aa06d-6ee1-49ae-9087-63e60d8c5fcd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.443013 [ 59098 ] {f1403035-4b1a-43e4-b4ec-e316a2c2f590} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonConvexHullCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.449487 [ 59098 ] {f1403035-4b1a-43e4-b4ec-e316a2c2f590} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.487677 [ 59098 ] {7665a6e8-0059-4b1e-b9f1-63f04422b0f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonPerimeterCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.492896 [ 59098 ] {7665a6e8-0059-4b1e-b9f1-63f04422b0f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.528541 [ 59098 ] {61dd9c86-c06e-409d-a077-b818dc35d2f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonPerimeterSpherical(NULL, NULL, NULL);) 2025.06.18 11:28:18.534447 [ 59098 ] {61dd9c86-c06e-409d-a077-b818dc35d2f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.576149 [ 59098 ] {b71fddfd-bca7-442e-b5dd-3f4fa6676db1} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsDistanceCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.581480 [ 59098 ] {b71fddfd-bca7-442e-b5dd-3f4fa6676db1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.620155 [ 59098 ] {21107a31-a9e2-4d12-ac84-09a0a2a84206} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsDistanceSpherical(NULL, NULL, NULL);) 2025.06.18 11:28:18.636998 [ 59098 ] {21107a31-a9e2-4d12-ac84-09a0a2a84206} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.675443 [ 59098 ] {c302ca7e-256a-4783-8421-e20e2567b9d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsEqualsCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.681091 [ 59098 ] {c302ca7e-256a-4783-8421-e20e2567b9d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.722757 [ 59098 ] {42660c06-16ac-490d-b743-866b3b5d83e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsIntersectionCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.730457 [ 59098 ] {42660c06-16ac-490d-b743-866b3b5d83e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.778301 [ 59098 ] {95291d12-68ff-46dd-a583-2221cdfa1e72} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsIntersectionSpherical(NULL, NULL, NULL);) 2025.06.18 11:28:18.787233 [ 59098 ] {95291d12-68ff-46dd-a583-2221cdfa1e72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.851594 [ 59098 ] {17818421-ea9d-46cf-8d52-226d06d42445} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.857327 [ 59098 ] {17818421-ea9d-46cf-8d52-226d06d42445} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.905857 [ 59098 ] {c4f84ad4-5cc1-4b6a-b7f7-687d48278655} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL);) 2025.06.18 11:28:18.912681 [ 59098 ] {c4f84ad4-5cc1-4b6a-b7f7-687d48278655} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.954088 [ 59098 ] {88b27321-2ad8-48c1-a29b-031b99c87247} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsUnionCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:18.959455 [ 59098 ] {88b27321-2ad8-48c1-a29b-031b99c87247} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:18.997088 [ 59098 ] {41b8914d-b966-41a1-af13-d6a02ae4f32e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsUnionSpherical(NULL, NULL, NULL);) 2025.06.18 11:28:19.002076 [ 59098 ] {41b8914d-b966-41a1-af13-d6a02ae4f32e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.043801 [ 59098 ] {95e4cf79-8692-4edf-bfb8-a9574d632d9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsWithinCartesian(NULL, NULL, NULL);) 2025.06.18 11:28:19.049142 [ 59098 ] {95e4cf79-8692-4edf-bfb8-a9574d632d9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.083476 [ 59098 ] {c79972bd-4cee-420e-adcc-71268d84c30d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsWithinSpherical(NULL, NULL, NULL);) 2025.06.18 11:28:19.088596 [ 59098 ] {c79972bd-4cee-420e-adcc-71268d84c30d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.569977 [ 59098 ] {d6770d22-f225-45a9-9617-a54316de761b} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT positiveModulo(NULL, NULL, NULL);) 2025.06.18 11:28:19.575116 [ 59098 ] {d6770d22-f225-45a9-9617-a54316de761b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.610192 [ 59098 ] {abe6b7bc-ca69-407c-97f1-1bbdea166379} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT positive_modulo(NULL, NULL, NULL);) 2025.06.18 11:28:19.615566 [ 59098 ] {abe6b7bc-ca69-407c-97f1-1bbdea166379} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.649131 [ 59098 ] {e7dea17f-242e-4320-a456-f29079aff237} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pow(NULL, NULL, NULL);) 2025.06.18 11:28:19.654475 [ 59098 ] {e7dea17f-242e-4320-a456-f29079aff237} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.689934 [ 59098 ] {3fdefd55-7ff4-41e7-a6b8-fd153893ae4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT power(NULL, NULL, NULL);) 2025.06.18 11:28:19.695288 [ 59098 ] {3fdefd55-7ff4-41e7-a6b8-fd153893ae4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.804635 [ 59098 ] {79e83385-18d4-4d17-b52e-2ee26ea93451} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT proportionsZTest(NULL, NULL, NULL);) 2025.06.18 11:28:19.809924 [ 59098 ] {79e83385-18d4-4d17-b52e-2ee26ea93451} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.844446 [ 59098 ] {ddb0cfa0-5e2d-4e57-bf3d-0e88859cff75} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT protocol(NULL, NULL, NULL);) 2025.06.18 11:28:19.848813 [ 59098 ] {ddb0cfa0-5e2d-4e57-bf3d-0e88859cff75} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.880036 [ 59098 ] {88dac974-af96-4b9a-9808-3cd21a91f1c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT punycodeDecode(NULL, NULL, NULL);) 2025.06.18 11:28:19.884575 [ 59098 ] {88dac974-af96-4b9a-9808-3cd21a91f1c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:19.918244 [ 59098 ] {1f78d9cd-cdac-4a09-8261-f4fc7a575e21} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT punycodeEncode(NULL, NULL, NULL);) 2025.06.18 11:28:19.922844 [ 59098 ] {1f78d9cd-cdac-4a09-8261-f4fc7a575e21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:21.708602 [ 59098 ] {44fb8d29-e371-4124-bcc3-5bbb7ff4f383} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantiles(NULL, NULL, NULL);) 2025.06.18 11:28:21.713917 [ 59098 ] {44fb8d29-e371-4124-bcc3-5bbb7ff4f383} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:21.750208 [ 59098 ] {e0718fd3-b6ce-4ba5-b7bf-7b8cb43a4720} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesBFloat16(NULL, NULL, NULL);) 2025.06.18 11:28:21.755681 [ 59098 ] {e0718fd3-b6ce-4ba5-b7bf-7b8cb43a4720} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:21.888793 [ 59098 ] {56eb2406-bc3d-4d6d-b058-c1805259fe56} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesDD(NULL, NULL, NULL);) 2025.06.18 11:28:21.894230 [ 59098 ] {56eb2406-bc3d-4d6d-b058-c1805259fe56} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:21.932884 [ 59098 ] {dbd29764-d4cc-4410-8258-8c7eea725585} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesDeterministic(NULL, NULL, NULL);) 2025.06.18 11:28:21.938780 [ 59098 ] {dbd29764-d4cc-4410-8258-8c7eea725585} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:21.980871 [ 59098 ] {ffa77101-266c-41b9-9993-ea16044291e4} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExact(NULL, NULL, NULL);) 2025.06.18 11:28:21.986856 [ 59098 ] {ffa77101-266c-41b9-9993-ea16044291e4} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.029089 [ 59098 ] {5cd47191-bd0d-48da-bb33-39247ec09062} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactExclusive(NULL, NULL, NULL);) 2025.06.18 11:28:22.035450 [ 59098 ] {5cd47191-bd0d-48da-bb33-39247ec09062} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.078788 [ 59098 ] {ca0d246c-f6ff-499a-ba6d-96e97711f901} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactHigh(NULL, NULL, NULL);) 2025.06.18 11:28:22.085285 [ 59098 ] {ca0d246c-f6ff-499a-ba6d-96e97711f901} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.122814 [ 59098 ] {ef5f16ed-eda2-4216-a844-f49b8f994833} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactInclusive(NULL, NULL, NULL);) 2025.06.18 11:28:22.128170 [ 59098 ] {ef5f16ed-eda2-4216-a844-f49b8f994833} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.162928 [ 59098 ] {4343509f-b1fe-4636-8fc6-e4db278a39a6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactLow(NULL, NULL, NULL);) 2025.06.18 11:28:22.168364 [ 59098 ] {4343509f-b1fe-4636-8fc6-e4db278a39a6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.203470 [ 59098 ] {4ce86534-beeb-4fc9-be0a-c1021cc447b2} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactWeighted(NULL, NULL, NULL);) 2025.06.18 11:28:22.208693 [ 59098 ] {4ce86534-beeb-4fc9-be0a-c1021cc447b2} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.248002 [ 59098 ] {8eee0d58-4fa8-45cd-ae6f-8c889d1a8a0b} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesGK(NULL, NULL, NULL);) 2025.06.18 11:28:22.255222 [ 59098 ] {8eee0d58-4fa8-45cd-ae6f-8c889d1a8a0b} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.302262 [ 59098 ] {2429f3b7-a406-49c9-82b0-8411177df237} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL, NULL);) 2025.06.18 11:28:22.308545 [ 59098 ] {2429f3b7-a406-49c9-82b0-8411177df237} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.350173 [ 59098 ] {3e13e4e2-affc-4e80-aa2d-9371c3f6454c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTDigest(NULL, NULL, NULL);) 2025.06.18 11:28:22.357560 [ 59098 ] {3e13e4e2-affc-4e80-aa2d-9371c3f6454c} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.395913 [ 59098 ] {3b1b6154-33b9-435f-ac55-5e8fd5858891} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTDigestWeighted(NULL, NULL, NULL);) 2025.06.18 11:28:22.401917 [ 59098 ] {3b1b6154-33b9-435f-ac55-5e8fd5858891} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.443071 [ 59098 ] {357197cb-9f02-4790-8177-449b5562405b} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTiming(NULL, NULL, NULL);) 2025.06.18 11:28:22.448844 [ 59098 ] {357197cb-9f02-4790-8177-449b5562405b} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.488358 [ 59098 ] {ecdd7f26-b824-4206-bff4-e8a303cabb94} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTimingWeighted(NULL, NULL, NULL);) 2025.06.18 11:28:22.495266 [ 59098 ] {ecdd7f26-b824-4206-bff4-e8a303cabb94} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:22.537445 [ 59098 ] {da1c25c9-b4f8-4bb7-a014-87abb1308675} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryID(NULL, NULL, NULL);) 2025.06.18 11:28:22.543267 [ 59098 ] {da1c25c9-b4f8-4bb7-a014-87abb1308675} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:22.584931 [ 59098 ] {e84a190f-abb0-48a9-a59d-7b1c3f60c2a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryString(NULL, NULL, NULL);) 2025.06.18 11:28:22.591458 [ 59098 ] {e84a190f-abb0-48a9-a59d-7b1c3f60c2a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:22.635063 [ 59098 ] {e5135f8e-d200-497d-8f31-f6d4f6e5524f} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryStringAndFragment(NULL, NULL, NULL);) 2025.06.18 11:28:22.642710 [ 59098 ] {e5135f8e-d200-497d-8f31-f6d4f6e5524f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:22.695032 [ 59098 ] {68cecc23-5298-4aa3-8974-8984ef44af22} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT query_id(NULL, NULL, NULL);) 2025.06.18 11:28:22.701743 [ 59098 ] {68cecc23-5298-4aa3-8974-8984ef44af22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:22.739667 [ 59098 ] {0cc1c9ca-ce83-4b04-b9da-439ae346fdac} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT radians(NULL, NULL, NULL);) 2025.06.18 11:28:22.747490 [ 59098 ] {0cc1c9ca-ce83-4b04-b9da-439ae346fdac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:22.782708 [ 59098 ] {e47b447a-1082-4f85-a0d2-1f200ff0f101} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand(NULL, NULL, NULL);) 2025.06.18 11:28:22.788402 [ 59098 ] {e47b447a-1082-4f85-a0d2-1f200ff0f101} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:22.823945 [ 59098 ] {32a98e01-719b-463a-9ebc-f7d380bdb9cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand32(NULL, NULL, NULL);) 2025.06.18 11:28:22.829152 [ 59098 ] {32a98e01-719b-463a-9ebc-f7d380bdb9cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:22.867133 [ 59098 ] {f5e5d390-2da0-4101-9e0d-079dcac24401} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand64(NULL, NULL, NULL);) 2025.06.18 11:28:22.873791 [ 59098 ] {f5e5d390-2da0-4101-9e0d-079dcac24401} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:23.079003 [ 59098 ] {d9d7e8ff-72b2-419b-baaa-cfc8d2b89df9} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randCanonical(NULL, NULL, NULL);) 2025.06.18 11:28:23.085763 [ 59098 ] {d9d7e8ff-72b2-419b-baaa-cfc8d2b89df9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:23.207007 [ 59098 ] {4d6a2fb5-53e8-4d96-adb5-5bea519c7140} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randConstant(NULL, NULL, NULL);) 2025.06.18 11:28:23.212956 [ 59098 ] {4d6a2fb5-53e8-4d96-adb5-5bea519c7140} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:23.867281 [ 59098 ] {44dd4b12-b8d4-4d75-917b-c0c06d2017b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randomFixedString(NULL, NULL, NULL);) 2025.06.18 11:28:23.872883 [ 59098 ] {44dd4b12-b8d4-4d75-917b-c0c06d2017b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.066534 [ 59098 ] {c7645001-a9d8-4425-9d51-f391a5f44391} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randomStringUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:24.072800 [ 59098 ] {c7645001-a9d8-4425-9d51-f391a5f44391} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.220897 [ 59098 ] {7def5f41-ab5f-4854-b26b-0f588b8dc4fe} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rank(NULL, NULL, NULL);) 2025.06.18 11:28:24.233166 [ 59098 ] {7def5f41-ab5f-4854-b26b-0f588b8dc4fe} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:28:24.391846 [ 59098 ] {7f766881-c772-464e-9103-41344106cbbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTLineString(NULL, NULL, NULL);) 2025.06.18 11:28:24.397187 [ 59098 ] {7f766881-c772-464e-9103-41344106cbbb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.440991 [ 59098 ] {2b0904c8-ed2d-4d44-aec5-41094d466b70} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTMultiLineString(NULL, NULL, NULL);) 2025.06.18 11:28:24.447322 [ 59098 ] {2b0904c8-ed2d-4d44-aec5-41094d466b70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.508328 [ 59098 ] {eeed2e7d-6a2f-47c4-8694-8011ea2c40c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTMultiPolygon(NULL, NULL, NULL);) 2025.06.18 11:28:24.515174 [ 59098 ] {eeed2e7d-6a2f-47c4-8694-8011ea2c40c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.551508 [ 59098 ] {2b56b7fd-c8a5-4db1-a88e-2b2fd7bc9a13} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTPoint(NULL, NULL, NULL);) 2025.06.18 11:28:24.557221 [ 59098 ] {2b56b7fd-c8a5-4db1-a88e-2b2fd7bc9a13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.597929 [ 59098 ] {67b2399a-66f9-489e-947d-5fc4f74911a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTPolygon(NULL, NULL, NULL);) 2025.06.18 11:28:24.603339 [ 59098 ] {67b2399a-66f9-489e-947d-5fc4f74911a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.643741 [ 59098 ] {34947fdf-65db-415c-af58-ba6aeeb8d3da} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTRing(NULL, NULL, NULL);) 2025.06.18 11:28:24.650643 [ 59098 ] {34947fdf-65db-415c-af58-ba6aeeb8d3da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:24.792735 [ 59098 ] {81b2cecc-54a2-44d7-b278-2648966b471e} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT regexpQuoteMeta(NULL, NULL, NULL);) 2025.06.18 11:28:24.803694 [ 59098 ] {81b2cecc-54a2-44d7-b278-2648966b471e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.605848 [ 59098 ] {65d6caf4-74c7-4b06-9ad2-f91c8977b3a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpret(NULL, NULL, NULL);) 2025.06.18 11:28:25.611405 [ 59098 ] {65d6caf4-74c7-4b06-9ad2-f91c8977b3a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.651111 [ 59098 ] {054d233e-14f3-427c-8911-d44b0bd97fe8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsDate(NULL, NULL, NULL);) 2025.06.18 11:28:25.656640 [ 59098 ] {054d233e-14f3-427c-8911-d44b0bd97fe8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.696127 [ 59098 ] {cab41939-c4df-4e42-90cd-050ad4e135b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsDateTime(NULL, NULL, NULL);) 2025.06.18 11:28:25.701568 [ 59098 ] {cab41939-c4df-4e42-90cd-050ad4e135b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.738347 [ 59098 ] {5908537c-95da-4afb-af1d-9aff5242b608} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFixedString(NULL, NULL, NULL);) 2025.06.18 11:28:25.743814 [ 59098 ] {5908537c-95da-4afb-af1d-9aff5242b608} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.782614 [ 59098 ] {aca4efd3-6cfb-45b0-adaf-02eb1e4ddc17} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFloat32(NULL, NULL, NULL);) 2025.06.18 11:28:25.788451 [ 59098 ] {aca4efd3-6cfb-45b0-adaf-02eb1e4ddc17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.826055 [ 59098 ] {6bed427e-443a-40dd-b787-e35e03a0cddc} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFloat64(NULL, NULL, NULL);) 2025.06.18 11:28:25.831613 [ 59098 ] {6bed427e-443a-40dd-b787-e35e03a0cddc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.870868 [ 59098 ] {34fc12c7-91b6-485a-8721-8e03a449e79f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt128(NULL, NULL, NULL);) 2025.06.18 11:28:25.877308 [ 59098 ] {34fc12c7-91b6-485a-8721-8e03a449e79f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.916089 [ 59098 ] {a0765f38-7a6b-443b-a79c-f409e6a0fd20} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt16(NULL, NULL, NULL);) 2025.06.18 11:28:25.921545 [ 59098 ] {a0765f38-7a6b-443b-a79c-f409e6a0fd20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:25.962522 [ 59098 ] {81bd25f6-cf42-431e-91ec-a78d17096331} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt256(NULL, NULL, NULL);) 2025.06.18 11:28:25.967921 [ 59098 ] {81bd25f6-cf42-431e-91ec-a78d17096331} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.008130 [ 59098 ] {bfe1d016-1237-48df-9a1a-d1a6e54be427} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt32(NULL, NULL, NULL);) 2025.06.18 11:28:26.013466 [ 59098 ] {bfe1d016-1237-48df-9a1a-d1a6e54be427} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.061054 [ 59098 ] {0a3f51c8-2294-4d78-a0b1-9de0ad75597b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt64(NULL, NULL, NULL);) 2025.06.18 11:28:26.067860 [ 59098 ] {0a3f51c8-2294-4d78-a0b1-9de0ad75597b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.116711 [ 59098 ] {fe502154-e871-4c73-a752-c28140c819bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt8(NULL, NULL, NULL);) 2025.06.18 11:28:26.123504 [ 59098 ] {fe502154-e871-4c73-a752-c28140c819bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.163240 [ 59098 ] {d4b13ac7-ca91-4cb4-bf28-4a5b1ba0ccd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsString(NULL, NULL, NULL);) 2025.06.18 11:28:26.168924 [ 59098 ] {d4b13ac7-ca91-4cb4-bf28-4a5b1ba0ccd5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.206365 [ 59098 ] {28dcf7ca-1b68-4744-8533-11e35419780b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt128(NULL, NULL, NULL);) 2025.06.18 11:28:26.211890 [ 59098 ] {28dcf7ca-1b68-4744-8533-11e35419780b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.247310 [ 59098 ] {2031bd76-3e0f-4bd7-b936-42d40991c097} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt16(NULL, NULL, NULL);) 2025.06.18 11:28:26.253433 [ 59098 ] {2031bd76-3e0f-4bd7-b936-42d40991c097} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.293466 [ 59098 ] {4a2bd854-af58-4968-b4f8-ea429f62efae} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt256(NULL, NULL, NULL);) 2025.06.18 11:28:26.298603 [ 59098 ] {4a2bd854-af58-4968-b4f8-ea429f62efae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.332943 [ 59098 ] {0fa6cafc-890a-4ba3-99b2-d22b90498734} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt32(NULL, NULL, NULL);) 2025.06.18 11:28:26.338379 [ 59098 ] {0fa6cafc-890a-4ba3-99b2-d22b90498734} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.371132 [ 59098 ] {9d5b5162-feba-44fc-b16e-76b6448efe36} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt64(NULL, NULL, NULL);) 2025.06.18 11:28:26.376099 [ 59098 ] {9d5b5162-feba-44fc-b16e-76b6448efe36} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.410156 [ 59098 ] {cb75c529-22d6-4fd2-8147-2a04193b1a66} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt8(NULL, NULL, NULL);) 2025.06.18 11:28:26.415095 [ 59098 ] {cb75c529-22d6-4fd2-8147-2a04193b1a66} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.450464 [ 59098 ] {3d8478ef-259f-4389-8589-4c0604da5f73} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUUID(NULL, NULL, NULL);) 2025.06.18 11:28:26.455448 [ 59098 ] {3d8478ef-259f-4389-8589-4c0604da5f73} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.499923 [ 59098 ] {17afc597-a523-4e33-977b-1b710736e99d} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT repeat(NULL, NULL, NULL);) 2025.06.18 11:28:26.506050 [ 59098 ] {17afc597-a523-4e33-977b-1b710736e99d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:26.972534 [ 59098 ] {bd17f345-e231-465d-8804-6035d2d56af6} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT replicate(NULL, NULL, NULL);) 2025.06.18 11:28:26.978853 [ 59098 ] {bd17f345-e231-465d-8804-6035d2d56af6} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:27.140085 [ 59098 ] {d0b12312-9166-4f06-a746-5fb71ce95ce8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reverse(NULL, NULL, NULL);) 2025.06.18 11:28:27.146235 [ 59098 ] {d0b12312-9166-4f06-a746-5fb71ce95ce8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.192051 [ 59098 ] {82341d26-0f32-4180-a3a1-db8dec908468} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reverseUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:27.198921 [ 59098 ] {82341d26-0f32-4180-a3a1-db8dec908468} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.243237 [ 59098 ] {60a9fa1d-e40e-4fbf-8a1e-ab5e8b482b43} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT revision(NULL, NULL, NULL);) 2025.06.18 11:28:27.249575 [ 59098 ] {60a9fa1d-e40e-4fbf-8a1e-ab5e8b482b43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.286061 [ 59098 ] {e6068946-476d-4633-84a4-0616bc2e10a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT right(NULL, NULL, NULL);) 2025.06.18 11:28:27.292027 [ 59098 ] {e6068946-476d-4633-84a4-0616bc2e10a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.543461 [ 59098 ] {55f74069-68a9-407c-b31d-ff71c0b813be} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rightUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:27.550793 [ 59098 ] {55f74069-68a9-407c-b31d-ff71c0b813be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.683089 [ 59098 ] {e01c7afa-4cf6-4e7e-9333-e2ed6c771c90} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundAge(NULL, NULL, NULL);) 2025.06.18 11:28:27.689679 [ 59098 ] {e01c7afa-4cf6-4e7e-9333-e2ed6c771c90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.806473 [ 59098 ] {70677e7f-48e6-4bc0-bbd7-6b54645fbfa4} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundDown(NULL, NULL, NULL);) 2025.06.18 11:28:27.813049 [ 59098 ] {70677e7f-48e6-4bc0-bbd7-6b54645fbfa4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.851732 [ 59098 ] {b6362fa1-6328-47e3-bcb9-24161ac0b081} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundDuration(NULL, NULL, NULL);) 2025.06.18 11:28:27.857905 [ 59098 ] {b6362fa1-6328-47e3-bcb9-24161ac0b081} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.903387 [ 59098 ] {c678d0a5-b354-4a58-bc5b-3724a33c95fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundToExp2(NULL, NULL, NULL);) 2025.06.18 11:28:27.912151 [ 59098 ] {c678d0a5-b354-4a58-bc5b-3724a33c95fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:27.969419 [ 59098 ] {719835a8-e39f-41dc-91b0-ba283178d1e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rowNumberInAllBlocks(NULL, NULL, NULL);) 2025.06.18 11:28:27.976380 [ 59098 ] {719835a8-e39f-41dc-91b0-ba283178d1e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.010854 [ 59098 ] {dea0b7b3-6e58-40fb-9e6a-7a8494862667} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rowNumberInBlock(NULL, NULL, NULL);) 2025.06.18 11:28:28.016422 [ 59098 ] {dea0b7b3-6e58-40fb-9e6a-7a8494862667} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.096410 [ 59098 ] {aa7494b4-380d-45e3-841f-c26b39394cd0} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT row_number(NULL, NULL, NULL);) 2025.06.18 11:28:28.105523 [ 59098 ] {aa7494b4-380d-45e3-841f-c26b39394cd0} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.18 11:28:28.220017 [ 59098 ] {10ef31b1-6882-41a9-998d-73dc8ba5b0fe} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningAccumulate(NULL, NULL, NULL);) 2025.06.18 11:28:28.225629 [ 59098 ] {10ef31b1-6882-41a9-998d-73dc8ba5b0fe} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:28:28.261075 [ 59098 ] {14f35b6e-dc4b-493b-9554-d8b6a6c9f7de} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningConcurrency(NULL, NULL, NULL);) 2025.06.18 11:28:28.266624 [ 59098 ] {14f35b6e-dc4b-493b-9554-d8b6a6c9f7de} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.304296 [ 59098 ] {682bdce3-12fc-4ea2-9aeb-1d8aaa63cf83} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningDifference(NULL, NULL, NULL);) 2025.06.18 11:28:28.310108 [ 59098 ] {682bdce3-12fc-4ea2-9aeb-1d8aaa63cf83} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:28:28.343584 [ 59098 ] {24859d2d-6931-4bd5-8ea5-345d7d2e4a74} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL, NULL);) 2025.06.18 11:28:28.348645 [ 59098 ] {24859d2d-6931-4bd5-8ea5-345d7d2e4a74} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.18 11:28:28.449656 [ 59098 ] {38a6e310-43a8-4ba3-acab-8e678a7a0403} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2CapUnion(NULL, NULL, NULL);) 2025.06.18 11:28:28.455714 [ 59098 ] {38a6e310-43a8-4ba3-acab-8e678a7a0403} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.488659 [ 59098 ] {3e515b4c-bea7-4857-a2fd-2eefb84442fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2CellsIntersect(NULL, NULL, NULL);) 2025.06.18 11:28:28.493582 [ 59098 ] {3e515b4c-bea7-4857-a2fd-2eefb84442fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.528238 [ 59098 ] {324fcce1-fa12-4f59-b283-1fb356516714} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2GetNeighbors(NULL, NULL, NULL);) 2025.06.18 11:28:28.533337 [ 59098 ] {324fcce1-fa12-4f59-b283-1fb356516714} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.699388 [ 59098 ] {6a87c724-4749-4519-80c9-57ae23bced73} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2RectIntersection(NULL, NULL, NULL);) 2025.06.18 11:28:28.704740 [ 59098 ] {6a87c724-4749-4519-80c9-57ae23bced73} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.734885 [ 59098 ] {23d54c87-51db-46ae-a869-93755e07b755} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2RectUnion(NULL, NULL, NULL);) 2025.06.18 11:28:28.739832 [ 59098 ] {23d54c87-51db-46ae-a869-93755e07b755} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.777140 [ 59098 ] {5853ac77-008e-43d3-b9e6-cb93dd513f47} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2ToGeo(NULL, NULL, NULL);) 2025.06.18 11:28:28.782313 [ 59098 ] {5853ac77-008e-43d3-b9e6-cb93dd513f47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:28.820472 [ 59098 ] {75bb60d7-6a05-44e9-9d47-b9d51bfdd740} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT scalarProduct(NULL, NULL, NULL);) 2025.06.18 11:28:28.825964 [ 59098 ] {75bb60d7-6a05-44e9-9d47-b9d51bfdd740} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.043585 [ 59098 ] {c25bee18-3811-497e-97b4-03bc3461273c} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sequenceNextNode(NULL, NULL, NULL);) 2025.06.18 11:28:29.048880 [ 59098 ] {c25bee18-3811-497e-97b4-03bc3461273c} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.18 11:28:29.085155 [ 59098 ] {672480d3-45b5-4498-ba63-b6a9f83338c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT seriesDecomposeSTL(NULL, NULL, NULL);) 2025.06.18 11:28:29.090407 [ 59098 ] {672480d3-45b5-4498-ba63-b6a9f83338c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.194925 [ 59098 ] {4f956724-d6ff-4192-8f86-f518a347a365} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL, NULL);) 2025.06.18 11:28:29.200752 [ 59098 ] {4f956724-d6ff-4192-8f86-f518a347a365} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.237101 [ 59098 ] {ae4d0f31-e878-4e67-bf9e-ead04613845e} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverTimeZone(NULL, NULL, NULL);) 2025.06.18 11:28:29.243711 [ 59098 ] {ae4d0f31-e878-4e67-bf9e-ead04613845e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.276688 [ 59098 ] {9bd85a84-f548-4449-aaea-92a4dec80d80} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverTimezone(NULL, NULL, NULL);) 2025.06.18 11:28:29.281825 [ 59098 ] {9bd85a84-f548-4449-aaea-92a4dec80d80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.315698 [ 59098 ] {1379bb5b-1b03-44c4-9104-016795f9026e} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverUUID(NULL, NULL, NULL);) 2025.06.18 11:28:29.320887 [ 59098 ] {1379bb5b-1b03-44c4-9104-016795f9026e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.351827 [ 59098 ] {db34435e-6e35-4464-a0bd-824cd6f1e025} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT shardCount(NULL, NULL, NULL);) 2025.06.18 11:28:29.356598 [ 59098 ] {db34435e-6e35-4464-a0bd-824cd6f1e025} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.392914 [ 59098 ] {aabf962e-9de6-44ef-8931-41369328be4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT shardNum(NULL, NULL, NULL);) 2025.06.18 11:28:29.400163 [ 59098 ] {aabf962e-9de6-44ef-8931-41369328be4c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.437736 [ 59098 ] {a9993b83-0c63-4054-90f2-9e8a76d2adc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT showCertificate(NULL, NULL, NULL);) 2025.06.18 11:28:29.443943 [ 59098 ] {a9993b83-0c63-4054-90f2-9e8a76d2adc9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.483412 [ 59098 ] {bcc2d2e0-c75a-46c5-9bfc-b980474412a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sigmoid(NULL, NULL, NULL);) 2025.06.18 11:28:29.489438 [ 59098 ] {bcc2d2e0-c75a-46c5-9bfc-b980474412a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.527217 [ 59098 ] {19387875-9645-44d8-8081-505136ea9fe6} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sign(NULL, NULL, NULL);) 2025.06.18 11:28:29.532507 [ 59098 ] {19387875-9645-44d8-8081-505136ea9fe6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.569007 [ 59098 ] {f2baeaee-4e88-439a-a441-23657629286c} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractBool(NULL, NULL, NULL);) 2025.06.18 11:28:29.575401 [ 59098 ] {f2baeaee-4e88-439a-a441-23657629286c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.615626 [ 59098 ] {d3686f57-f51c-4178-8ad2-3011381d7fe4} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractFloat(NULL, NULL, NULL);) 2025.06.18 11:28:29.622124 [ 59098 ] {d3686f57-f51c-4178-8ad2-3011381d7fe4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.659344 [ 59098 ] {5655dfa8-220c-4eeb-abd0-756361ff7613} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractInt(NULL, NULL, NULL);) 2025.06.18 11:28:29.665552 [ 59098 ] {5655dfa8-220c-4eeb-abd0-756361ff7613} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.701823 [ 59098 ] {f3c54384-56a5-4bac-9f15-151f2a36aeb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractRaw(NULL, NULL, NULL);) 2025.06.18 11:28:29.708131 [ 59098 ] {f3c54384-56a5-4bac-9f15-151f2a36aeb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.747400 [ 59098 ] {2934584e-c09a-4507-9fb1-6594f0632a1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractString(NULL, NULL, NULL);) 2025.06.18 11:28:29.753132 [ 59098 ] {2934584e-c09a-4507-9fb1-6594f0632a1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.789433 [ 59098 ] {9b2b458e-59c1-4f09-a66a-fe3eca1ba353} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractUInt(NULL, NULL, NULL);) 2025.06.18 11:28:29.794848 [ 59098 ] {9b2b458e-59c1-4f09-a66a-fe3eca1ba353} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.834639 [ 59098 ] {d8774eec-5555-4e9e-9da7-0a0cbc066516} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONHas(NULL, NULL, NULL);) 2025.06.18 11:28:29.840511 [ 59098 ] {d8774eec-5555-4e9e-9da7-0a0cbc066516} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:29.976562 [ 59098 ] {f4122144-4c01-4a14-82b1-cca5e53ac083} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sin(NULL, NULL, NULL);) 2025.06.18 11:28:29.983222 [ 59098 ] {f4122144-4c01-4a14-82b1-cca5e53ac083} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:30.124301 [ 59098 ] {f4a1d299-9cfe-42f7-8a9b-a68b7844340f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sinh(NULL, NULL, NULL);) 2025.06.18 11:28:30.129643 [ 59098 ] {f4a1d299-9cfe-42f7-8a9b-a68b7844340f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:30.817124 [ 59098 ] {1745c33b-2afe-4184-8b39-e817e8756ebd} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sleep(NULL, NULL, NULL);) 2025.06.18 11:28:30.824149 [ 59098 ] {1745c33b-2afe-4184-8b39-e817e8756ebd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:30.860566 [ 59098 ] {fa9c6240-216c-4aae-99d6-d149301cefa0} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sleepEachRow(NULL, NULL, NULL);) 2025.06.18 11:28:30.867030 [ 59098 ] {fa9c6240-216c-4aae-99d6-d149301cefa0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:31.218272 [ 59098 ] {1e7e80ba-aca8-494b-b4c0-f57fe8a676be} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT soundex(NULL, NULL, NULL);) 2025.06.18 11:28:31.223584 [ 59098 ] {1e7e80ba-aca8-494b-b4c0-f57fe8a676be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:31.259492 [ 59098 ] {2b6f3190-afb6-4828-9de3-ea1fe7143551} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT space(NULL, NULL, NULL);) 2025.06.18 11:28:31.265316 [ 59098 ] {2b6f3190-afb6-4828-9de3-ea1fe7143551} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:32.043182 [ 59098 ] {bd96bcbc-e024-4b35-b129-bcff112dc924} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sqidDecode(NULL, NULL, NULL);) 2025.06.18 11:28:32.049655 [ 59098 ] {bd96bcbc-e024-4b35-b129-bcff112dc924} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:32.173495 [ 59098 ] {2c4d7b33-863f-42d1-942d-2d73638145fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sqrt(NULL, NULL, NULL);) 2025.06.18 11:28:32.178728 [ 59098 ] {2c4d7b33-863f-42d1-942d-2d73638145fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:32.218039 [ 59098 ] {c58f819c-9679-4ce5-9614-b8fa1610d3c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT startsWith(NULL, NULL, NULL);) 2025.06.18 11:28:32.223621 [ 59098 ] {c58f819c-9679-4ce5-9614-b8fa1610d3c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:32.260953 [ 59098 ] {e4980af4-142c-42a3-bb77-8b85b1e7d560} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT startsWithUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:32.266546 [ 59098 ] {e4980af4-142c-42a3-bb77-8b85b1e7d560} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:32.710646 [ 59098 ] {20b4ee04-1204-43ed-a1d6-8f39e194280b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stem(NULL, NULL, NULL);) 2025.06.18 11:28:32.716308 [ 59098 ] {20b4ee04-1204-43ed-a1d6-8f39e194280b} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:28:33.089912 [ 59098 ] {e824fcd1-2f2b-4569-b86c-e794ad597471} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringJaccardIndex(NULL, NULL, NULL);) 2025.06.18 11:28:33.095374 [ 59098 ] {e824fcd1-2f2b-4569-b86c-e794ad597471} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:33.135329 [ 59098 ] {287d3185-1179-43a1-8f26-d7b843e3fde1} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringJaccardIndexUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:33.140706 [ 59098 ] {287d3185-1179-43a1-8f26-d7b843e3fde1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:33.174894 [ 59098 ] {b0217b9e-4369-4a93-bafd-ee90497e26e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringToH3(NULL, NULL, NULL);) 2025.06.18 11:28:33.180364 [ 59098 ] {b0217b9e-4369-4a93-bafd-ee90497e26e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:33.216392 [ 59098 ] {67bf7271-34ca-4dca-8354-5b7eb6a4eecf} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT structureToCapnProtoSchema(NULL, NULL, NULL);) 2025.06.18 11:28:33.222116 [ 59098 ] {67bf7271-34ca-4dca-8354-5b7eb6a4eecf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:33.258806 [ 59098 ] {76b69f9a-ba72-4ddf-91ee-452c526184e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT structureToProtobufSchema(NULL, NULL, NULL);) 2025.06.18 11:28:33.264415 [ 59098 ] {76b69f9a-ba72-4ddf-91ee-452c526184e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:33.457690 [ 59098 ] {ac1f8892-f035-4051-82ed-ca025471af22} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subDate(NULL, NULL, NULL);) 2025.06.18 11:28:33.462909 [ 59098 ] {ac1f8892-f035-4051-82ed-ca025471af22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:34.017275 [ 59098 ] {6f592981-9e9d-4845-8bfc-56072cc6934f} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subtractInterval(NULL, NULL, NULL);) 2025.06.18 11:28:34.022655 [ 59098 ] {6f592981-9e9d-4845-8bfc-56072cc6934f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:34.630636 [ 59098 ] {70acf14b-6c26-44cc-b655-c494a10e9593} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subtractTupleOfIntervals(NULL, NULL, NULL);) 2025.06.18 11:28:34.637098 [ 59098 ] {70acf14b-6c26-44cc-b655-c494a10e9593} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:35.716262 [ 59098 ] {7b94cfe7-5f82-494d-9b03-190834c2ed33} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT synonyms(NULL, NULL, NULL);) 2025.06.18 11:28:35.725998 [ 59098 ] {7b94cfe7-5f82-494d-9b03-190834c2ed33} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.18 11:28:35.783815 [ 59098 ] {8f42576b-5767-43ad-87e8-ffe56e0d8249} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tan(NULL, NULL, NULL);) 2025.06.18 11:28:35.792639 [ 59098 ] {8f42576b-5767-43ad-87e8-ffe56e0d8249} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:35.835285 [ 59098 ] {97cbe3b9-0f61-41a0-b28c-55b522da2d9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tanh(NULL, NULL, NULL);) 2025.06.18 11:28:35.843546 [ 59098 ] {97cbe3b9-0f61-41a0-b28c-55b522da2d9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:35.901897 [ 59098 ] {9a89c6b5-a398-4f4b-a385-8b3a257b89b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tcpPort(NULL, NULL, NULL);) 2025.06.18 11:28:35.908903 [ 59098 ] {9a89c6b5-a398-4f4b-a385-8b3a257b89b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:35.947692 [ 59098 ] {e7fa267a-6555-444a-85a3-52af62067c22} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT test_function(NULL, NULL, NULL);) 2025.06.18 11:28:35.953190 [ 59098 ] {e7fa267a-6555-444a-85a3-52af62067c22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:35.985024 [ 59098 ] {82d9f04c-89bd-42cb-98a0-ff43551fea5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tgamma(NULL, NULL, NULL);) 2025.06.18 11:28:35.989893 [ 59098 ] {82d9f04c-89bd-42cb-98a0-ff43551fea5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.189869 [ 59098 ] {117cf14a-f738-40d0-9495-d2ef99a98083} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tid(NULL, NULL, NULL);) 2025.06.18 11:28:36.194716 [ 59098 ] {117cf14a-f738-40d0-9495-d2ef99a98083} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.224911 [ 59098 ] {3037e5b7-5612-4596-8528-dde21f9fc05c} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeDiff(NULL, NULL, NULL);) 2025.06.18 11:28:36.229140 [ 59098 ] {3037e5b7-5612-4596-8528-dde21f9fc05c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.413587 [ 59098 ] {15900978-8fc5-4109-a6ac-d8285c1a02f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeZone(NULL, NULL, NULL);) 2025.06.18 11:28:36.418236 [ 59098 ] {15900978-8fc5-4109-a6ac-d8285c1a02f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.448880 [ 59098 ] {15e183c9-5e06-4b95-a84d-c3f1163e9e52} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeZoneOf(NULL, NULL, NULL);) 2025.06.18 11:28:36.453800 [ 59098 ] {15e183c9-5e06-4b95-a84d-c3f1163e9e52} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.806533 [ 59098 ] {97164bcc-858b-4133-af3f-b6df24c640fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timezone(NULL, NULL, NULL);) 2025.06.18 11:28:36.812068 [ 59098 ] {97164bcc-858b-4133-af3f-b6df24c640fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.843722 [ 59098 ] {91525844-afd7-4c86-bbd6-583c0a256ba0} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timezoneOf(NULL, NULL, NULL);) 2025.06.18 11:28:36.848659 [ 59098 ] {91525844-afd7-4c86-bbd6-583c0a256ba0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.948411 [ 59098 ] {0181ab60-1823-48ee-bd54-8cdfbea13148} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toBool(NULL, NULL, NULL);) 2025.06.18 11:28:36.953698 [ 59098 ] {0181ab60-1823-48ee-bd54-8cdfbea13148} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:36.987577 [ 59098 ] {8a27aae0-d4a9-45ff-ab36-93b3d9c5f261} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toColumnTypeName(NULL, NULL, NULL);) 2025.06.18 11:28:36.992835 [ 59098 ] {8a27aae0-d4a9-45ff-ab36-93b3d9c5f261} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:37.165731 [ 59098 ] {633c926f-3806-487c-8720-501659273992} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDate32OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:37.171162 [ 59098 ] {633c926f-3806-487c-8720-501659273992} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:37.343992 [ 59098 ] {52196c81-fd88-44ae-87df-2d94589b442f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateOrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:37.349944 [ 59098 ] {52196c81-fd88-44ae-87df-2d94589b442f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:37.765037 [ 59098 ] {cb40ad25-7d4d-4d02-b415-d317b1b10f56} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateTime64OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:37.771556 [ 59098 ] {cb40ad25-7d4d-4d02-b415-d317b1b10f56} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:37.953824 [ 59098 ] {2b10cd3a-6f80-4be6-ad4e-347ab0f5adbd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateTimeOrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:37.959254 [ 59098 ] {2b10cd3a-6f80-4be6-ad4e-347ab0f5adbd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:38.501415 [ 59098 ] {02db732e-e39b-4613-93aa-fad7f1662a9f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal128OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:38.507521 [ 59098 ] {02db732e-e39b-4613-93aa-fad7f1662a9f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:38.755887 [ 59098 ] {b14387d1-e1e7-4017-a65e-e1a8bf089ef9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal256OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:38.761116 [ 59098 ] {b14387d1-e1e7-4017-a65e-e1a8bf089ef9} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:39.026732 [ 59098 ] {a0b5015e-c3c4-4b8c-8e90-ce0c04aaa789} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal32OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:39.033058 [ 59098 ] {a0b5015e-c3c4-4b8c-8e90-ce0c04aaa789} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:39.293107 [ 59098 ] {d100708c-d116-4c73-93d0-18477af6e383} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal64OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:39.298345 [ 59098 ] {d100708c-d116-4c73-93d0-18477af6e383} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:39.483361 [ 59098 ] {636e6d63-891d-439a-befc-431c788548c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimalString(NULL, NULL, NULL);) 2025.06.18 11:28:39.488524 [ 59098 ] {636e6d63-891d-439a-befc-431c788548c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:39.521888 [ 59098 ] {fe13c831-919a-4f10-a0fe-cfdd9dd04495} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFixedString(NULL, NULL, NULL);) 2025.06.18 11:28:39.527124 [ 59098 ] {fe13c831-919a-4f10-a0fe-cfdd9dd04495} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:39.641760 [ 59098 ] {1e918c02-f3b5-4b6c-846a-f617911ddfa0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFloat32OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:39.648152 [ 59098 ] {1e918c02-f3b5-4b6c-846a-f617911ddfa0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:39.901688 [ 59098 ] {6dc58521-9184-45a6-baeb-76268c631d9e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFloat64OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:39.907140 [ 59098 ] {6dc58521-9184-45a6-baeb-76268c631d9e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:40.234880 [ 59098 ] {efb95bea-4c24-479f-9ed8-35bc050cfa01} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toIPv4OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:40.241456 [ 59098 ] {efb95bea-4c24-479f-9ed8-35bc050cfa01} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:40.506623 [ 59098 ] {9e7ce7b0-8568-4f84-bda4-4cb037b4556c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toIPv6OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:40.513083 [ 59098 ] {9e7ce7b0-8568-4f84-bda4-4cb037b4556c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:40.961562 [ 59098 ] {92efb35e-d345-420b-8888-711a9c53b983} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt128OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:40.968077 [ 59098 ] {92efb35e-d345-420b-8888-711a9c53b983} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:41.235575 [ 59098 ] {9f514153-35a8-4561-b5ae-b4135114a2dd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt16OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:41.242136 [ 59098 ] {9f514153-35a8-4561-b5ae-b4135114a2dd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:41.541156 [ 59098 ] {40a469d2-1e3e-47c0-8c78-0b1755a94ee9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt256OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:41.547153 [ 59098 ] {40a469d2-1e3e-47c0-8c78-0b1755a94ee9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:41.820986 [ 59098 ] {fd0b66a1-8a9a-439a-82de-7767e7fdfc3b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt32OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:41.827383 [ 59098 ] {fd0b66a1-8a9a-439a-82de-7767e7fdfc3b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:42.095556 [ 59098 ] {d7d2dfc7-0970-42c4-98d4-e0e9da52b576} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt64OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:42.102133 [ 59098 ] {d7d2dfc7-0970-42c4-98d4-e0e9da52b576} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:42.378078 [ 59098 ] {92209245-55d9-4782-a224-e054a46c068a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt8OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:42.384898 [ 59098 ] {92209245-55d9-4782-a224-e054a46c068a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:43.353855 [ 59098 ] {42136df3-d2cc-475e-81d4-fcb89ef83fda} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toJSONString(NULL, NULL, NULL);) 2025.06.18 11:28:43.358838 [ 59098 ] {42136df3-d2cc-475e-81d4-fcb89ef83fda} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:43.522469 [ 59098 ] {72333ec3-e9c5-4f21-8bb8-272e66a68a2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toLowCardinality(NULL, NULL, NULL);) 2025.06.18 11:28:43.527623 [ 59098 ] {72333ec3-e9c5-4f21-8bb8-272e66a68a2c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:43.698674 [ 59098 ] {cd288cae-b16c-4aab-b79f-669e5d19508a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toModifiedJulianDay(NULL, NULL, NULL);) 2025.06.18 11:28:43.703870 [ 59098 ] {cd288cae-b16c-4aab-b79f-669e5d19508a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:43.733064 [ 59098 ] {e5a19453-28f9-49dc-8a17-86bfda5fc622} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.06.18 11:28:43.738333 [ 59098 ] {e5a19453-28f9-49dc-8a17-86bfda5fc622} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:43.896392 [ 59098 ] {9aff7f3a-b5a1-4794-97b3-edf0c11ea574} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toNullable(NULL, NULL, NULL);) 2025.06.18 11:28:43.902238 [ 59098 ] {9aff7f3a-b5a1-4794-97b3-edf0c11ea574} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:46.082112 [ 59098 ] {f3417ae1-c8e8-4fae-aedb-a36c1efd833d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toStringCutToZero(NULL, NULL, NULL);) 2025.06.18 11:28:46.087294 [ 59098 ] {f3417ae1-c8e8-4fae-aedb-a36c1efd833d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:46.199271 [ 59098 ] {c1de5a7e-d5c3-462c-bf92-5bb525761273} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTimeZone(NULL, NULL, NULL);) 2025.06.18 11:28:46.205051 [ 59098 ] {c1de5a7e-d5c3-462c-bf92-5bb525761273} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:46.242685 [ 59098 ] {ff5087ff-f090-43ad-9ef8-fdf0ed553f94} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTimezone(NULL, NULL, NULL);) 2025.06.18 11:28:46.248047 [ 59098 ] {ff5087ff-f090-43ad-9ef8-fdf0ed553f94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:46.279496 [ 59098 ] {267d79d2-32d9-42da-ab54-466560dfa75b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTypeName(NULL, NULL, NULL);) 2025.06.18 11:28:46.284764 [ 59098 ] {267d79d2-32d9-42da-ab54-466560dfa75b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:46.402378 [ 59098 ] {63b8a7a4-0968-4129-ab1d-f6adfbeb5508} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt128OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:46.416959 [ 59098 ] {63b8a7a4-0968-4129-ab1d-f6adfbeb5508} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:46.673624 [ 59098 ] {bb4d0085-bdb2-409b-80e0-d4eb91939ab3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt16OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:46.678981 [ 59098 ] {bb4d0085-bdb2-409b-80e0-d4eb91939ab3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:46.929518 [ 59098 ] {b15668d8-792c-4e38-b757-492f23bab6d1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt256OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:46.934446 [ 59098 ] {b15668d8-792c-4e38-b757-492f23bab6d1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:47.156634 [ 59098 ] {b178a001-49a5-48fa-bdf5-b3efa8f41d26} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt32OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:47.161478 [ 59098 ] {b178a001-49a5-48fa-bdf5-b3efa8f41d26} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:47.405751 [ 59098 ] {9e5aed6b-6011-416a-8b5e-1d4e394e6d99} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt64OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:47.411324 [ 59098 ] {9e5aed6b-6011-416a-8b5e-1d4e394e6d99} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:47.656936 [ 59098 ] {d8cda074-2ae5-482e-9233-54f091edfaaa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt8OrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:47.662516 [ 59098 ] {d8cda074-2ae5-482e-9233-54f091edfaaa} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:47.849194 [ 59098 ] {251e5a69-658e-42ab-baf7-b12d1c8be7b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUTCTimestamp(NULL, NULL, NULL);) 2025.06.18 11:28:47.855324 [ 59098 ] {251e5a69-658e-42ab-baf7-b12d1c8be7b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:47.980706 [ 59098 ] {06a25b50-4011-4c1c-a2f8-da6a3fc88546} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUUIDOrDefault(NULL, NULL, NULL);) 2025.06.18 11:28:47.987745 [ 59098 ] {06a25b50-4011-4c1c-a2f8-da6a3fc88546} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:48.280475 [ 59098 ] {c65b2b6f-400a-4341-b6dc-34607c5bd2ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL, NULL);) 2025.06.18 11:28:48.285293 [ 59098 ] {c65b2b6f-400a-4341-b6dc-34607c5bd2ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:48.322161 [ 59098 ] {64494e55-d851-46e4-bae9-97a745031745} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL, NULL);) 2025.06.18 11:28:48.330015 [ 59098 ] {64494e55-d851-46e4-bae9-97a745031745} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:48.363040 [ 59098 ] {4cf135e7-dbdf-48ba-9d5d-b29507b4942f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL, NULL);) 2025.06.18 11:28:48.368563 [ 59098 ] {4cf135e7-dbdf-48ba-9d5d-b29507b4942f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:48.403020 [ 59098 ] {72fd57bc-45bd-4910-94ee-d15bc606f60e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toValidUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:48.408484 [ 59098 ] {72fd57bc-45bd-4910-94ee-d15bc606f60e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:48.853814 [ 59098 ] {1f978ac1-2661-497f-887c-79cd57956016} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT to_utc_timestamp(NULL, NULL, NULL);) 2025.06.18 11:28:48.858560 [ 59098 ] {1f978ac1-2661-497f-887c-79cd57956016} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:48.888279 [ 59098 ] {1fa7f3ba-3e12-451f-a381-c8737563014d} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT today(NULL, NULL, NULL);) 2025.06.18 11:28:48.892983 [ 59098 ] {1fa7f3ba-3e12-451f-a381-c8737563014d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:48.923764 [ 59098 ] {550a8969-a5af-4c69-b381-d991dcc40475} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tokens(NULL, NULL, NULL);) 2025.06.18 11:28:48.929498 [ 59098 ] {550a8969-a5af-4c69-b381-d991dcc40475} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.131061 [ 59098 ] {c26c136d-06e7-467c-affc-7008c09553cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT topLevelDomain(NULL, NULL, NULL);) 2025.06.18 11:28:49.135888 [ 59098 ] {c26c136d-06e7-467c-affc-7008c09553cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.165548 [ 59098 ] {154f1f4f-61b4-445b-84d1-93c22f163ce7} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT topLevelDomainRFC(NULL, NULL, NULL);) 2025.06.18 11:28:49.170617 [ 59098 ] {154f1f4f-61b4-445b-84d1-93c22f163ce7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.202504 [ 59098 ] {16417f53-d51e-4bb9-9917-9618c9278c50} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionID(NULL, NULL, NULL);) 2025.06.18 11:28:49.207586 [ 59098 ] {16417f53-d51e-4bb9-9917-9618c9278c50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.240684 [ 59098 ] {061b0e1e-385c-4a0d-9c45-c7a17fdca416} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionLatestSnapshot(NULL, NULL, NULL);) 2025.06.18 11:28:49.246026 [ 59098 ] {061b0e1e-385c-4a0d-9c45-c7a17fdca416} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.280179 [ 59098 ] {3cdda434-dee2-43a0-968d-856e51a0c35e} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionOldestSnapshot(NULL, NULL, NULL);) 2025.06.18 11:28:49.286207 [ 59098 ] {3cdda434-dee2-43a0-968d-856e51a0c35e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.318628 [ 59098 ] {0a7fa533-fd9d-4b14-b506-7a2946dc05f7} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transform(NULL, NULL, NULL);) 2025.06.18 11:28:49.323579 [ 59098 ] {0a7fa533-fd9d-4b14-b506-7a2946dc05f7} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:49.488958 [ 59098 ] {5ecf08d5-8436-4119-9acd-be7b9f5a1a5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimBoth(NULL, NULL, NULL);) 2025.06.18 11:28:49.498948 [ 59098 ] {5ecf08d5-8436-4119-9acd-be7b9f5a1a5d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.529340 [ 59098 ] {ff78d4ea-cc9a-4e06-a759-c5714ec38fc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimLeft(NULL, NULL, NULL);) 2025.06.18 11:28:49.534030 [ 59098 ] {ff78d4ea-cc9a-4e06-a759-c5714ec38fc9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.564941 [ 59098 ] {e0994ce1-0c89-4c12-919f-0f7b0e35aaf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimRight(NULL, NULL, NULL);) 2025.06.18 11:28:49.570165 [ 59098 ] {e0994ce1-0c89-4c12-919f-0f7b0e35aaf8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.727227 [ 59098 ] {0a27139a-e62a-4eec-8e11-8346c504af0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase58Decode(NULL, NULL, NULL);) 2025.06.18 11:28:49.732680 [ 59098 ] {0a27139a-e62a-4eec-8e11-8346c504af0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.764384 [ 59098 ] {cd2566bd-8e73-47cc-9f1c-4b09af656031} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase64Decode(NULL, NULL, NULL);) 2025.06.18 11:28:49.769718 [ 59098 ] {cd2566bd-8e73-47cc-9f1c-4b09af656031} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.800852 [ 59098 ] {70259c5c-1732-42da-a78d-edec9600c840} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase64URLDecode(NULL, NULL, NULL);) 2025.06.18 11:28:49.806234 [ 59098 ] {70259c5c-1732-42da-a78d-edec9600c840} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.903283 [ 59098 ] {63e9010b-aef0-454f-8122-ddcb6a07c8ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryIdnaEncode(NULL, NULL, NULL);) 2025.06.18 11:28:49.908146 [ 59098 ] {63e9010b-aef0-454f-8122-ddcb6a07c8ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:49.937524 [ 59098 ] {373554a0-8d86-4bd5-b6f6-08200630f552} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryPunycodeDecode(NULL, NULL, NULL);) 2025.06.18 11:28:49.942121 [ 59098 ] {373554a0-8d86-4bd5-b6f6-08200630f552} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.282375 [ 59098 ] {0c45dccd-ea07-4685-9e54-42a4a42285c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleDivide(NULL, NULL, NULL);) 2025.06.18 11:28:50.287368 [ 59098 ] {0c45dccd-ea07-4685-9e54-42a4a42285c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.318412 [ 59098 ] {37a8b93f-4d78-4f01-925e-f0756af0f227} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleDivideByNumber(NULL, NULL, NULL);) 2025.06.18 11:28:50.323032 [ 59098 ] {37a8b93f-4d78-4f01-925e-f0756af0f227} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.352711 [ 59098 ] {ae611291-520a-4397-bc99-2ee1a7dfdf5e} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleElement(NULL, NULL, NULL);) 2025.06.18 11:28:50.357394 [ 59098 ] {ae611291-520a-4397-bc99-2ee1a7dfdf5e} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:50.386944 [ 59098 ] {4dc6b330-b582-4a9f-b3e2-b67fc027770b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleHammingDistance(NULL, NULL, NULL);) 2025.06.18 11:28:50.391574 [ 59098 ] {4dc6b330-b582-4a9f-b3e2-b67fc027770b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.420261 [ 59098 ] {949031f8-8687-4d63-95b5-a6244a1b5aea} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDiv(NULL, NULL, NULL);) 2025.06.18 11:28:50.424786 [ 59098 ] {949031f8-8687-4d63-95b5-a6244a1b5aea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.455080 [ 59098 ] {26887294-83fd-48d8-b759-c17cec4bc14a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivByNumber(NULL, NULL, NULL);) 2025.06.18 11:28:50.459825 [ 59098 ] {26887294-83fd-48d8-b759-c17cec4bc14a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.489625 [ 59098 ] {ffc5c861-a7ce-4591-a98b-3432eb6750d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivOrZero(NULL, NULL, NULL);) 2025.06.18 11:28:50.494365 [ 59098 ] {ffc5c861-a7ce-4591-a98b-3432eb6750d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.525748 [ 59098 ] {f3ddba1b-e091-4f79-a287-ea281e7fb29a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL);) 2025.06.18 11:28:50.530461 [ 59098 ] {f3ddba1b-e091-4f79-a287-ea281e7fb29a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.559711 [ 59098 ] {509f3477-7a41-4228-9c85-f9432c9078d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMinus(NULL, NULL, NULL);) 2025.06.18 11:28:50.564340 [ 59098 ] {509f3477-7a41-4228-9c85-f9432c9078d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.594292 [ 59098 ] {5b0ed11c-64f5-4d66-a74f-29575e5e30b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleModulo(NULL, NULL, NULL);) 2025.06.18 11:28:50.599300 [ 59098 ] {5b0ed11c-64f5-4d66-a74f-29575e5e30b3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.630587 [ 59098 ] {a16d7c39-2719-4229-ab92-25aeab9c31f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleModuloByNumber(NULL, NULL, NULL);) 2025.06.18 11:28:50.635500 [ 59098 ] {a16d7c39-2719-4229-ab92-25aeab9c31f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.665878 [ 59098 ] {417fe075-8e8f-4943-a15a-51102c68d345} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMultiply(NULL, NULL, NULL);) 2025.06.18 11:28:50.671455 [ 59098 ] {417fe075-8e8f-4943-a15a-51102c68d345} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.701677 [ 59098 ] {5c8ecca4-b94d-4db4-96c4-cbfb0cc51b5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMultiplyByNumber(NULL, NULL, NULL);) 2025.06.18 11:28:50.706366 [ 59098 ] {5c8ecca4-b94d-4db4-96c4-cbfb0cc51b5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.735333 [ 59098 ] {a85f7d8e-5cdb-4517-9d8d-0fffe070e7f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleNames(NULL, NULL, NULL);) 2025.06.18 11:28:50.740013 [ 59098 ] {a85f7d8e-5cdb-4517-9d8d-0fffe070e7f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.770215 [ 59098 ] {bf5fbd46-9901-46db-9595-42352ed2f7fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleNegate(NULL, NULL, NULL);) 2025.06.18 11:28:50.775130 [ 59098 ] {bf5fbd46-9901-46db-9595-42352ed2f7fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.805286 [ 59098 ] {693328c9-73e5-48b7-b410-889178ac4fe9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tuplePlus(NULL, NULL, NULL);) 2025.06.18 11:28:50.810054 [ 59098 ] {693328c9-73e5-48b7-b410-889178ac4fe9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.839996 [ 59098 ] {87d3e451-a7c0-4290-92d9-4de5d619ea0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleToNameValuePairs(NULL, NULL, NULL);) 2025.06.18 11:28:50.844750 [ 59098 ] {87d3e451-a7c0-4290-92d9-4de5d619ea0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.874111 [ 59098 ] {73450bd8-045b-48d7-a505-ebeaba22167a} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ucase(NULL, NULL, NULL);) 2025.06.18 11:28:50.878690 [ 59098 ] {73450bd8-045b-48d7-a505-ebeaba22167a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.907426 [ 59098 ] {0ec0b4a1-e1fb-45d9-b0ef-5b988bce55bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT unbin(NULL, NULL, NULL);) 2025.06.18 11:28:50.912065 [ 59098 ] {0ec0b4a1-e1fb-45d9-b0ef-5b988bce55bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:50.941607 [ 59098 ] {e08dcb9e-4e13-4bf8-84a2-ba866780290a} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT unhex(NULL, NULL, NULL);) 2025.06.18 11:28:50.946212 [ 59098 ] {e08dcb9e-4e13-4bf8-84a2-ba866780290a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:51.470383 [ 59098 ] {e45ea0cf-f552-4270-a4fb-5025b0fba1f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaIntersect(NULL, NULL, NULL);) 2025.06.18 11:28:51.475651 [ 59098 ] {e45ea0cf-f552-4270-a4fb-5025b0fba1f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:51.506541 [ 59098 ] {40b1d20a-23ff-426e-b602-66e7b3ba3d15} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaNot(NULL, NULL, NULL);) 2025.06.18 11:28:51.511501 [ 59098 ] {40b1d20a-23ff-426e-b602-66e7b3ba3d15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:51.541503 [ 59098 ] {49a9ce39-7ecd-4dc9-8dab-457fb34c8348} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaUnion(NULL, NULL, NULL);) 2025.06.18 11:28:51.546622 [ 59098 ] {49a9ce39-7ecd-4dc9-8dab-457fb34c8348} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:51.662049 [ 59098 ] {2e63805c-dbf7-43ec-86d1-379a24d388c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT upper(NULL, NULL, NULL);) 2025.06.18 11:28:51.667070 [ 59098 ] {2e63805c-dbf7-43ec-86d1-379a24d388c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:51.697557 [ 59098 ] {cd601295-4efd-4573-95ca-5f2975b244af} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT upperUTF8(NULL, NULL, NULL);) 2025.06.18 11:28:51.702434 [ 59098 ] {cd601295-4efd-4573-95ca-5f2975b244af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:51.733527 [ 59098 ] {f61bfe3b-1a85-49f4-afb2-3e76a6ba449f} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uptime(NULL, NULL, NULL);) 2025.06.18 11:28:51.738274 [ 59098 ] {f61bfe3b-1a85-49f4-afb2-3e76a6ba449f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:51.767979 [ 59098 ] {30c9be9b-b098-43ce-b669-16373e6a6b3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT user(NULL, NULL, NULL);) 2025.06.18 11:28:51.781681 [ 59098 ] {30c9be9b-b098-43ce-b669-16373e6a6b3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.203536 [ 59098 ] {ecb5f0af-9090-492b-b9ff-8cb6c6b5fc22} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT variantElement(NULL, NULL, NULL);) 2025.06.18 11:28:52.208096 [ 59098 ] {ecb5f0af-9090-492b-b9ff-8cb6c6b5fc22} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.18 11:28:52.236795 [ 59098 ] {8991bbd9-2a3d-44f3-b033-600fc731b484} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT variantType(NULL, NULL, NULL);) 2025.06.18 11:28:52.241580 [ 59098 ] {8991bbd9-2a3d-44f3-b033-600fc731b484} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.273908 [ 59098 ] {1d8da9eb-6383-404e-9ef9-7361fc6f64fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT vectorDifference(NULL, NULL, NULL);) 2025.06.18 11:28:52.279221 [ 59098 ] {1d8da9eb-6383-404e-9ef9-7361fc6f64fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.309677 [ 59098 ] {fdc12a71-d0b4-4b5c-8804-c31f3b561128} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT vectorSum(NULL, NULL, NULL);) 2025.06.18 11:28:52.314671 [ 59098 ] {fdc12a71-d0b4-4b5c-8804-c31f3b561128} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.346120 [ 59098 ] {c78d5704-db10-473f-892e-f1d2861c3559} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT version(NULL, NULL, NULL);) 2025.06.18 11:28:52.351542 [ 59098 ] {c78d5704-db10-473f-892e-f1d2861c3559} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.381809 [ 59098 ] {a23901b1-0862-4004-b7f3-a440b5472213} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visibleWidth(NULL, NULL, NULL);) 2025.06.18 11:28:52.386601 [ 59098 ] {a23901b1-0862-4004-b7f3-a440b5472213} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.417308 [ 59098 ] {cb9d3765-559b-4aa0-8793-d54de55bfaf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractBool(NULL, NULL, NULL);) 2025.06.18 11:28:52.422188 [ 59098 ] {cb9d3765-559b-4aa0-8793-d54de55bfaf8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.452230 [ 59098 ] {aed5a035-993f-4f5e-8037-5bf5c75484b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractFloat(NULL, NULL, NULL);) 2025.06.18 11:28:52.457300 [ 59098 ] {aed5a035-993f-4f5e-8037-5bf5c75484b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.487999 [ 59098 ] {30effb4a-cf8c-4e34-87e0-53677e147ec3} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractInt(NULL, NULL, NULL);) 2025.06.18 11:28:52.493249 [ 59098 ] {30effb4a-cf8c-4e34-87e0-53677e147ec3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.523509 [ 59098 ] {b8fc163b-90b6-4837-bbb9-122bea9aa3a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractRaw(NULL, NULL, NULL);) 2025.06.18 11:28:52.528402 [ 59098 ] {b8fc163b-90b6-4837-bbb9-122bea9aa3a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.559120 [ 59098 ] {ea1ef615-ed1f-4b9e-9645-bdde21d8eb6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractString(NULL, NULL, NULL);) 2025.06.18 11:28:52.564327 [ 59098 ] {ea1ef615-ed1f-4b9e-9645-bdde21d8eb6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.595385 [ 59098 ] {223e92c0-5ff9-4a69-ba8c-11fbaf92ba9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractUInt(NULL, NULL, NULL);) 2025.06.18 11:28:52.600242 [ 59098 ] {223e92c0-5ff9-4a69-ba8c-11fbaf92ba9d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.630770 [ 59098 ] {3cc527d8-c337-4805-be92-43e95474ce99} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamHas(NULL, NULL, NULL);) 2025.06.18 11:28:52.635747 [ 59098 ] {3cc527d8-c337-4805-be92-43e95474ce99} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.814403 [ 59098 ] {51040f6a-ced7-48c8-9589-22b6253c5a20} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT widthBucket(NULL, NULL, NULL);) 2025.06.18 11:28:52.819439 [ 59098 ] {51040f6a-ced7-48c8-9589-22b6253c5a20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:52.850339 [ 59098 ] {ca7fcd17-3da1-40bf-877b-b754e06dbe40} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT width_bucket(NULL, NULL, NULL);) 2025.06.18 11:28:52.855132 [ 59098 ] {ca7fcd17-3da1-40bf-877b-b754e06dbe40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:53.036245 [ 59098 ] {b717f510-6561-46e7-87e9-36694c2b8945} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT wkt(NULL, NULL, NULL);) 2025.06.18 11:28:53.041146 [ 59098 ] {b717f510-6561-46e7-87e9-36694c2b8945} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:54.123193 [ 59098 ] {bff60122-2c4d-4111-ae1d-de009e1651d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT yandexConsistentHash(NULL, NULL, NULL);) 2025.06.18 11:28:54.128035 [ 59098 ] {bff60122-2c4d-4111-ae1d-de009e1651d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:54.219612 [ 59098 ] {2fadbdaf-3859-4a54-8389-d809756b2ffe} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT yesterday(NULL, NULL, NULL);) 2025.06.18 11:28:54.225481 [ 59098 ] {2fadbdaf-3859-4a54-8389-d809756b2ffe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:28:54.257283 [ 59098 ] {8a1470a2-bff6-417b-90b1-0ee69af362a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37790) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT zookeeperSessionUptime(NULL, NULL, NULL);) 2025.06.18 11:28:54.262089 [ 59098 ] {8a1470a2-bff6-417b-90b1-0ee69af362a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.18 11:29:04.522488 [ 25755 ] {66ca35d6-3c76-4d65-84fb-3416304809c3} executeQuery: Code: 57. DB::Exception: Directory for table data store/7ad/7ad36356-46ee-4f72-bc81-7c892e1027d5/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '7ad36356-46ee-4f72-bc81-7c892e1027d5' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 55526, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 163127831, compact_parts_max_bytes_to_buffer = 305046307, compact_parts_max_granules_to_buffer = 133, compact_parts_merge_max_bytes_to_prefetch_part = 7652228, merge_max_block_size = 11964, old_parts_lifetime = 400., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 21, min_merge_bytes_to_use_direct_io = 5509822524, index_granularity_bytes = 26900353, concurrent_part_removal_threshold = 81, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 48051, primary_key_compress_block_size = 76052), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1600: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d9fc0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395311e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003394c42c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000033943596 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000003392e73a 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000003397dba6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003397d95f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:29:04.529987 [ 25755 ] {66ca35d6-3c76-4d65-84fb-3416304809c3} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '7ad36356-46ee-4f72-bc81-7c892e1027d5' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 55526, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 163127831, compact_parts_max_bytes_to_buffer = 305046307, compact_parts_max_granules_to_buffer = 133, compact_parts_merge_max_bytes_to_prefetch_part = 7652228, merge_max_block_size = 11964, old_parts_lifetime = 400., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 21, min_merge_bytes_to_use_direct_io = 5509822524, index_granularity_bytes = 26900353, concurrent_part_removal_threshold = 81, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 48051, primary_key_compress_block_size = 76052 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7ad/7ad36356-46ee-4f72-bc81-7c892e1027d5/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1600: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d9fc0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b3177 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395311e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003394c42c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000033943596 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000003392e73a 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000003397dba6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003397d95f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:29:04.784397 [ 25755 ] {} DDLWorker(rdb2): Unexpected error (1 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7ad/7ad36356-46ee-4f72-bc81-7c892e1027d5/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003394df5f 5. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000033943596 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000003392e73a 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000003397dba6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003397d95f 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 11. ? @ 0x00007f8e6ce63ac3 12. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:29:12.590100 [ 59016 ] {5e3509d7-b037-4579-8458-eb52ea287f43} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a csv format file. Error: Code: 74. DB::ErrnoException: Cannot read from file /var/lib/clickhouse/user_files/data_03198_table_function_directory_path/dir2//dir: , errno: 21, strerror: Is a directory. (CANNOT_READ_FROM_FILE_DESCRIPTOR) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_03198_table_function_directory_path/dir2//dir). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59460) (comment: 03198_table_function_directory_path.sql) (in query: SELECT COUNT(*) FROM file('data_03198_table_function_directory_path/*/dir', 'csv');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad987e3 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038306112 7. ./src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383079cf 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830adc4 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310847 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:29:12.594894 [ 59016 ] {5e3509d7-b037-4579-8458-eb52ea287f43} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a csv format file. Error: Code: 74. DB::ErrnoException: Cannot read from file /var/lib/clickhouse/user_files/data_03198_table_function_directory_path/dir2//dir: , errno: 21, strerror: Is a directory. (CANNOT_READ_FROM_FILE_DESCRIPTOR) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_03198_table_function_directory_path/dir2//dir). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad987e3 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038306112 7. ./src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383079cf 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830adc4 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310847 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:29:13.323671 [ 59016 ] {1ed93c73-24fe-490f-b210-0c7b549e5ee7} executeQuery: Code: 400. DB::ErrnoException: Cannot stat file /var/lib/clickhouse/user_files/data_03198_table_function_directory_pat: , errno: 2, strerror: No such file or directory: The data format cannot be detected by the contents of the files. You can specify the format manually: (in file/uri /var/lib/clickhouse/user_files/data_03198_table_function_directory_pat). (CANNOT_STAT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:59460) (comment: 03198_table_function_directory_path.sql) (in query: SELECT COUNT(*) FROM file('data_03198_table_function_directory_pat');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000383558ef 4. ./build_docker/./src/Storages/StorageFile.cpp:326: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x0000000038347e16 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad896da 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9bc1e 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383061c5 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830d05c 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310847 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:29:13.326995 [ 59016 ] {1ed93c73-24fe-490f-b210-0c7b549e5ee7} TCPHandler: Code: 400. DB::ErrnoException: Cannot stat file /var/lib/clickhouse/user_files/data_03198_table_function_directory_pat: , errno: 2, strerror: No such file or directory: The data format cannot be detected by the contents of the files. You can specify the format manually: (in file/uri /var/lib/clickhouse/user_files/data_03198_table_function_directory_pat). (CANNOT_STAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000383558ef 4. ./build_docker/./src/Storages/StorageFile.cpp:326: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x0000000038347e16 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad896da 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9bc1e 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383061c5 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830d05c 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038310847 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038312480 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002fe3c0f9 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe34eb5 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe3ffa6 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 2025.06.18 11:29:15.750134 [ 59016 ] {12a38e90-6970-470a-893f-34fde3ef385b} executeQuery: Code: 60. DB::Exception: Table '' not found in database 'test_jy30fixk'. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36172) (comment: 03147_table_function_loop.sql) (in query: SELECT * FROM loop('', '') -- { serverError UNKNOWN_TABLE } ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x00000000083bdd8d 4. ./build_docker/./src/TableFunctions/TableFunctionLoop.cpp:120: DB::(anonymous namespace)::TableFunctionLoop::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdfac4d 5. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 6. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:29:15.753782 [ 59016 ] {12a38e90-6970-470a-893f-34fde3ef385b} TCPHandler: Code: 60. DB::Exception: Table '' not found in database 'test_jy30fixk'. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x00000000083bdd8d 4. ./build_docker/./src/TableFunctions/TableFunctionLoop.cpp:120: DB::(anonymous namespace)::TableFunctionLoop::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdfac4d 5. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f3733 6. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033740632 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033453731 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e1361 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a3c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 27. ? @ 0x00007f8e6ce63ac3 28. ? @ 0x00007f8e6cef5850 2025.06.18 11:38:35.339887 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.341161 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.359004 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.359994 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.372358 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.372823 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.384848 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.385431 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.398387 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.398984 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.409645 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.410144 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.425042 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.425782 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.438347 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.438879 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.455134 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.455664 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.468425 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.468976 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.481639 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.482063 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.495661 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.496163 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.508734 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.509228 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.521076 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.521555 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.532121 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.532629 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.544992 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.545519 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.557466 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.557966 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.569733 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.570216 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.581796 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.582257 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.593771 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.594229 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.605612 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.606009 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.617350 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.617739 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.627916 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.628370 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.639548 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.640048 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.652573 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.653116 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.664720 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.665202 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.677822 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.678210 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.690162 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.690712 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.705333 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.705916 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.718183 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.718667 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.730844 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.731377 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.747507 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.748010 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.760220 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.760733 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.775864 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.776433 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.789663 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.790224 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.804487 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.805064 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.819338 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.819926 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.834975 [ 1240 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.835517 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.850403 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.850931 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.864795 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.865417 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.877913 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.878518 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.891721 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.892251 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.908852 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.909474 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.924843 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.925355 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.941767 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.942201 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.958660 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.959215 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.975587 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.976086 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.989143 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:35.989587 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.003337 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.003799 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.016880 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.017327 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.029036 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.029571 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.041757 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.042298 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.056414 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.056957 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.069320 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.069900 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.082773 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.083271 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.095916 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.096428 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.107742 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.108239 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.121329 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.121869 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.134195 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.134614 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.147168 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.147731 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.159209 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.159728 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.172550 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.173032 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.186705 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.187218 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.199843 [ 1240 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.200427 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.213416 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.213940 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.235311 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.235843 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.249956 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.250454 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.264820 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.265421 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.279107 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.279658 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.293588 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.294113 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.307158 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.307653 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.319576 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.320099 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.332594 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.333239 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.346022 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.346577 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.359060 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.359588 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.373672 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.374226 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.387991 [ 1240 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.388497 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.403536 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.404713 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.426987 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.427525 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.441832 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.442345 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.455964 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.456479 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.470469 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.470977 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.484733 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.485306 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.499789 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.500285 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.514907 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.515476 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.528674 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.529260 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.542544 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.543077 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.556664 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.557235 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.569495 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.570012 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.583830 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.584355 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.596737 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.597228 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.610906 [ 1246 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.611362 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.624140 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.624663 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.636837 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.637364 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.650962 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.651482 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.663360 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.663881 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.676037 [ 1240 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.676545 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.687938 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.688473 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.701830 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.702352 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.716675 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.717261 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.729500 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.730133 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.742415 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.742913 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.755907 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.756406 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.773079 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.773926 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.789503 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.790623 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.803612 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.804136 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.817382 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.817914 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.832272 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.832858 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.845983 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.846501 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.859458 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.859925 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.872227 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.872782 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.884992 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.885499 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.898571 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.899106 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.911694 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.912274 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.925920 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.926383 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.937402 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.937912 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.949497 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.949977 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.962096 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.962597 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.975113 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.975650 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.988808 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:36.989418 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.001161 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.001667 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.017272 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.017786 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.030761 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.031272 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.044361 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.044809 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.058430 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.059050 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.071853 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.072372 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.085977 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.086485 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.100635 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.101242 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.113289 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.113732 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.139117 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.139632 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.151631 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.152225 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.165077 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.165589 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.177414 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.177964 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.189018 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.189489 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.201238 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.201849 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.212737 [ 1250 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.213225 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.223091 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.223590 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.235586 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.236168 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.247341 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.247809 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.258871 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.259291 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.270601 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.271138 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.284183 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.284761 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.297396 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.297934 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.312562 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.313435 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.326922 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.327677 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.341416 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.341969 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.357371 [ 1244 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.358153 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.375350 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.375923 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.391028 [ 1243 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.391523 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.408041 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.408676 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.422255 [ 1254 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.422817 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.438028 [ 1255 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.438515 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.453265 [ 1251 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.454069 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.467047 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.467532 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.481544 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.482102 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.494256 [ 1253 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.494803 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.509279 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.509943 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.522664 [ 1248 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.523181 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.538585 [ 1240 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.539455 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.552694 [ 1247 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.553141 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.566531 [ 1242 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.567027 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.580487 [ 1249 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.581046 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.593835 [ 1241 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.594330 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.607363 [ 1252 ] {} 4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:38:37.607910 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4bc43cf7-5f3d-49a5-9222-a3a8262f7188::all_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_vl1fv6iw%2Freplicas%2Fmaster&part=all_0_0_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a006ce3 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a003883 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:10.802673 [ 69958 ] {5facc780-8ac6-4f42-87f7-65adf7f1a9fc} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/1). (TABLE_IS_READ_ONLY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60974) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_1 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386d0472 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000388fc238 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:10.808068 [ 69958 ] {5facc780-8ac6-4f42-87f7-65adf7f1a9fc} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386d0472 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000388fc238 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bfcf1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:10.896197 [ 1154 ] {} test_qjshapzl.test_table_1 (b6c22346-fb13-4964-9407-3876f9284b0d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386d0472 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x0000000038892381 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8d41f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 12. ? @ 0x00007f8e6ce63ac3 13. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:12.639359 [ 69955 ] {d047b54f-1439-46d6-8c8f-83409ce93cbb} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 176.00 B) in table 'test_qjshapzl.test_table_2 (2dafe4b1-eee4-4fbc-b0be-7bd29a305dec)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57054) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:12.645964 [ 69955 ] {d047b54f-1439-46d6-8c8f-83409ce93cbb} TCPHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 176.00 B) in table 'test_qjshapzl.test_table_2 (2dafe4b1-eee4-4fbc-b0be-7bd29a305dec)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:13.269396 [ 69955 ] {cd23e779-d0b4-415c-8afd-b8ce25b34e97} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57068) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_1 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:13.275562 [ 69955 ] {cd23e779-d0b4-415c-8afd-b8ce25b34e97} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:16.066422 [ 69955 ] {3dc44203-6acd-4e67-94ca-a440d72d5e87} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_1 does not exist. Maybe you meant test_qjshapzl.test_table_10?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57150) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_1 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:16.071782 [ 69955 ] {3dc44203-6acd-4e67-94ca-a440d72d5e87} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_1 does not exist. Maybe you meant test_qjshapzl.test_table_10?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:17.482018 [ 69955 ] {79c56011-eec9-49da-8253-de2fad5815fe} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_4?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57184) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:17.489083 [ 69955 ] {79c56011-eec9-49da-8253-de2fad5815fe} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_4?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:17.907780 [ 69955 ] {ec547613-3426-4a6a-8400-4c2d63a22d74} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_4 does not exist. Maybe you meant test_qjshapzl.test_table_5?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57210) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_4 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:17.913294 [ 69955 ] {ec547613-3426-4a6a-8400-4c2d63a22d74} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_4 does not exist. Maybe you meant test_qjshapzl.test_table_5?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:18.118256 [ 69957 ] {2cf219a1-9062-4bfa-a22c-f391c9f415f3} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_2. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57220) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_2 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:18.123545 [ 69957 ] {2cf219a1-9062-4bfa-a22c-f391c9f415f3} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:18.207730 [ 1249 ] {} 813abf3a-a6b8-455f-a8ec-3969f9da829e::all_11_11_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.207857 [ 1243 ] {} e8235cec-65df-4db2-af32-2569ee4a2a62::all_11_11_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.207881 [ 1240 ] {} 6bac413f-5824-4225-9841-8dc90a16d2c5::all_11_11_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.207999 [ 1250 ] {} 133203f9-d078-486e-85e8-3dc397f23a8b::all_11_11_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #4, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208024 [ 1246 ] {} 3d2cb053-3026-4f49-bb42-0eeb1a67fb77::all_11_11_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #6, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208034 [ 1251 ] {} 468b96a5-2b40-49ab-80ba-c67507d037ce::all_11_11_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208738 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e8235cec-65df-4db2-af32-2569ee4a2a62::all_11_11_0_13}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208749 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {813abf3a-a6b8-455f-a8ec-3969f9da829e::all_11_11_0_13}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208749 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {133203f9-d078-486e-85e8-3dc397f23a8b::all_11_11_0_13}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #4, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208749 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6bac413f-5824-4225-9841-8dc90a16d2c5::all_11_11_0_13}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208782 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {468b96a5-2b40-49ab-80ba-c67507d037ce::all_11_11_0_13}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.208749 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3d2cb053-3026-4f49-bb42-0eeb1a67fb77::all_11_11_0_13}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #6, path: /clickhouse/tables/02962_system_sync_replica_lightweight_from_modifier_test_qjshapzl/test_table/replicas/4/parts/all_11_11_0_13. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf76f1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cbf7bf5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003879e38d 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039e4d2b5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a00374b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:39:18.941666 [ 69955 ] {32eab395-154d-4e0a-9f9c-b28790f22dac} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_5?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57232) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_3 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:18.946869 [ 69955 ] {32eab395-154d-4e0a-9f9c-b28790f22dac} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_5?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:18.986652 [ 69957 ] {11030830-c81f-4708-9de9-5e0ac8dd2b86} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_2. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57248) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_2 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:18.991689 [ 69957 ] {11030830-c81f-4708-9de9-5e0ac8dd2b86} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:19.268070 [ 69955 ] {a685b6b2-8ea5-4cdc-bf50-82ab1f66028b} executeQuery: Code: 252. DB::Exception: Too many parts (3 with average size of 117.00 B) in table 'test_qjshapzl.test_table_5 (468b96a5-2b40-49ab-80ba-c67507d037ce)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57272) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_5 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:19.276003 [ 69955 ] {a685b6b2-8ea5-4cdc-bf50-82ab1f66028b} TCPHandler: Code: 252. DB::Exception: Too many parts (3 with average size of 117.00 B) in table 'test_qjshapzl.test_table_5 (468b96a5-2b40-49ab-80ba-c67507d037ce)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:20.679711 [ 69958 ] {48bc0dc6-c881-4966-b245-e201ccc6d9d3} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_6?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57310) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_3 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:20.684772 [ 69958 ] {48bc0dc6-c881-4966-b245-e201ccc6d9d3} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_6?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:21.654116 [ 69955 ] {813313a4-f973-4ea6-909d-77ecce9949fe} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_1 does not exist. Maybe you meant test_qjshapzl.test_table_10?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41348) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:21.659631 [ 69955 ] {813313a4-f973-4ea6-909d-77ecce9949fe} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_1 does not exist. Maybe you meant test_qjshapzl.test_table_10?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:22.104981 [ 69957 ] {b0188385-8439-4e8d-8d3b-cf19e0b27258} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41364) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_3 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:22.110748 [ 69957 ] {b0188385-8439-4e8d-8d3b-cf19e0b27258} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:22.615203 [ 69955 ] {2c0eec27-3011-4732-9219-5b038d8c6969} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41380) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_3 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:22.621811 [ 69955 ] {2c0eec27-3011-4732-9219-5b038d8c6969} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:22.972677 [ 69955 ] {328d8de9-ff72-42c7-83dd-60498fe5b5fc} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41406) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_1 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:22.978193 [ 69955 ] {328d8de9-ff72-42c7-83dd-60498fe5b5fc} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:23.445667 [ 69957 ] {f49573d9-4195-4623-801d-ec26008bbfaf} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41434) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:23.450503 [ 69957 ] {f49573d9-4195-4623-801d-ec26008bbfaf} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:24.130161 [ 69958 ] {9b076bfc-8f29-42fe-90cc-b7cdd325cb6f} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_4 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41478) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_4 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:24.135060 [ 69958 ] {9b076bfc-8f29-42fe-90cc-b7cdd325cb6f} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_4 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:24.296302 [ 69955 ] {9bdc06bd-0f03-4b05-a115-f673c57d4bc6} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41488) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:24.301223 [ 69955 ] {9bdc06bd-0f03-4b05-a115-f673c57d4bc6} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_7?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:24.909903 [ 69955 ] {4b1c784d-35b1-46d0-b317-ab6175268a59} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_2. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41494) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_2 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:24.915388 [ 69955 ] {4b1c784d-35b1-46d0-b317-ab6175268a59} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:25.811625 [ 69958 ] {4571ca1f-3065-4992-93b3-097327a4aff7} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_3. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41522) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_3 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:25.820498 [ 69958 ] {4571ca1f-3065-4992-93b3-097327a4aff7} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_3. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:25.992303 [ 69959 ] {46851179-5fea-48d0-b485-86b8960f478c} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_6 does not exist. Maybe you meant test_qjshapzl.test_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41528) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_6 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:25.997986 [ 69959 ] {46851179-5fea-48d0-b485-86b8960f478c} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_6 does not exist. Maybe you meant test_qjshapzl.test_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:26.766109 [ 69958 ] {5fd113fb-e48d-4129-a781-2833260bac78} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41556) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_3 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:26.771585 [ 69958 ] {5fd113fb-e48d-4129-a781-2833260bac78} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_3 does not exist. Maybe you meant test_qjshapzl.test_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:27.645716 [ 69958 ] {73c35d5d-3961-401c-9a5d-a499f7aec92f} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_6 does not exist. Maybe you meant test_qjshapzl.test_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41576) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_6 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:27.646596 [ 69955 ] {78a837bb-e27a-417e-a8ae-238e9b116055} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_6. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:41570) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_6 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:27.651184 [ 69958 ] {73c35d5d-3961-401c-9a5d-a499f7aec92f} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_6 does not exist. Maybe you meant test_qjshapzl.test_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:27.651561 [ 69955 ] {78a837bb-e27a-417e-a8ae-238e9b116055} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_6. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:35.712651 [ 69947 ] {0237af5f-a336-42ef-ab6c-c3f5a63cd231} executeQuery: Code: 60. DB::Exception: Could not find table: test_table_1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34454) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: ALTER TABLE test_table_1 DELETE WHERE key % 2 = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:35.717690 [ 69947 ] {0237af5f-a336-42ef-ab6c-c3f5a63cd231} TCPHandler: Code: 60. DB::Exception: Could not find table: test_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485afc8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:35.840318 [ 69945 ] {2e4d1af6-4eaa-466d-bc18-6c9d515b579b} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_3?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34470) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:35.845221 [ 69945 ] {2e4d1af6-4eaa-466d-bc18-6c9d515b579b} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:36.790969 [ 69947 ] {ff93132d-8e47-4f44-8c34-3de47389a56c} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_3?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34518) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: OPTIMIZE TABLE test_table_2 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:36.796817 [ 69947 ] {ff93132d-8e47-4f44-8c34-3de47389a56c} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_2 does not exist. Maybe you meant test_qjshapzl.test_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359be0ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:37.494763 [ 69946 ] {704c25e9-cda5-4d10-8088-4310c8326b48} executeQuery: Code: 60. DB::Exception: Table test_qjshapzl.test_table_1 does not exist. Maybe you meant test_qjshapzl.test_table_10?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34526) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:37.500103 [ 69946 ] {704c25e9-cda5-4d10-8088-4310c8326b48} TCPHandler: Code: 60. DB::Exception: Table test_qjshapzl.test_table_1 does not exist. Maybe you meant test_qjshapzl.test_table_10?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:38.333519 [ 69946 ] {cbd5c790-6c14-485a-80b1-bf09e6f35d03} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 194.00 B) in table 'test_qjshapzl.test_table_4 (cbb81d1b-e5e9-404b-938c-d6184932a1cc)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34562) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: INSERT INTO test_table_4 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:38.341309 [ 69946 ] {cbd5c790-6c14-485a-80b1-bf09e6f35d03} TCPHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 194.00 B) in table 'test_qjshapzl.test_table_4 (cbb81d1b-e5e9-404b-938c-d6184932a1cc)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b1a77 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397ab018 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a1dde20 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b7ffcec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe4a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aec7460 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abccbad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 21. ? @ 0x00007f8e6ce63ac3 22. ? @ 0x00007f8e6cef5850 2025.06.18 11:39:38.375969 [ 69946 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:34562, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:25.906230 [ 1280 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:26.507507 [ 1285 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.112316 [ 1285 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.354693 [ 1281 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.903169 [ 1284 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.905527 [ 1286 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.910851 [ 1283 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.915776 [ 1281 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.921340 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.928023 [ 1286 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.934137 [ 1283 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.938826 [ 1285 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.943859 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.949569 [ 1280 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:27.956986 [ 1283 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.527577 [ 1280 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.677531 [ 1286 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.679447 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.755780 [ 1283 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.882213 [ 1284 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.884041 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.887884 [ 1283 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.889675 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.900774 [ 1281 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.902434 [ 1282 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.907058 [ 1284 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.909293 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.912498 [ 1281 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.914396 [ 1282 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.917979 [ 1284 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.920078 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.923364 [ 1281 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.925272 [ 1282 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.928824 [ 1284 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.931239 [ 1287 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.934274 [ 1281 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:28.936126 [ 1282 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:29.767618 [ 1285 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:30.094023 [ 1281 ] {} test_y9b4z579.data_r1 (1aebf60e-fcd4-4a38-b251-742f5dc42405): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2057: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387aa238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90dd9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:40:41.914519 [ 1344 ] {} DDLWorker: There are two the same ClickHouse instances in task query-0000000005: localhost:9000 and localhost:9000. Will use the first one only. 2025.06.18 11:40:50.706706 [ 1344 ] {} DDLWorker: There are two the same ClickHouse instances in task query-0000000006: localhost:9000 and localhost:9000. Will use the first one only. 2025.06.18 11:40:51.076825 [ 1344 ] {} DDLWorker: There are two the same ClickHouse instances in task query-0000000007: localhost:9000 and localhost:9000. Will use the first one only. 2025.06.18 11:40:56.505619 [ 69946 ] {1b92f88f-3ea7-425e-b09a-2d991a2d326b} executeQuery: Code: 36. DB::Exception: Cannot delete key `b` because it does not exist in collection. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46212) (comment: 02908_empty_named_collection.sql) (in query: ALTER NAMED COLLECTION foobar03 DELETE b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Common/NamedCollections/NamedCollectionsMetadataStorage.cpp:415: DB::NamedCollectionsMetadataStorage::update(DB::ASTAlterNamedCollectionQuery const&) @ 0x0000000030be0b4e 5. ./build_docker/./src/Common/NamedCollections/NamedCollectionsFactory.cpp:0: DB::NamedCollectionFactory::updateFromSQL(DB::ASTAlterNamedCollectionQuery const&) @ 0x0000000030bd1633 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterAlterNamedCollectionQuery::execute() @ 0x00000000359f322d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:40:56.508895 [ 69946 ] {1b92f88f-3ea7-425e-b09a-2d991a2d326b} TCPHandler: Code: 36. DB::Exception: Cannot delete key `b` because it does not exist in collection. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Common/NamedCollections/NamedCollectionsMetadataStorage.cpp:415: DB::NamedCollectionsMetadataStorage::update(DB::ASTAlterNamedCollectionQuery const&) @ 0x0000000030be0b4e 5. ./build_docker/./src/Common/NamedCollections/NamedCollectionsFactory.cpp:0: DB::NamedCollectionFactory::updateFromSQL(DB::ASTAlterNamedCollectionQuery const&) @ 0x0000000030bd1633 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterAlterNamedCollectionQuery::execute() @ 0x00000000359f322d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 11:40:59.098173 [ 69946 ] {b75e6110-8d4d-4fdb-8684-c460677a5f25} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Fault injection before operation. (UNKNOWN_STATUS_OF_INSERT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46222) (comment: 02887_insert_quorum_wo_keeper_retries.sql) (in query: INSERT INTO quorum1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: void std::__invoke_void_return_wrapper::__call::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda4'()&>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda4'()&) @ 0x000000003a23292c 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a232789 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000306770ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:68: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a232ada 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a1e9ebb 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1bbe74 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a1e6838 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:40:59.103668 [ 69946 ] {b75e6110-8d4d-4fdb-8684-c460677a5f25} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Fault injection before operation. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: void std::__invoke_void_return_wrapper::__call::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda4'()&>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda4'()&) @ 0x000000003a23292c 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a232789 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000306770ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:68: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a232ada 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a1e9ebb 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1bbe74 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a1e6838 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b800acf 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b7fe8c2 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aec8619 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abce9aa 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea16 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:42:17.475106 [ 69946 ] {ea198a62-1824-4e67-a0dd-fd63cf18fd46} executeQuery: Code: 36. DB::Exception: Replicated database requires 3 arguments: zookeeper path, shard name and replica name. (BAD_ARGUMENTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39342) (comment: 02762_replicated_database_no_args.sql) (in query: create database replicated_db_no_args engine=Replicated;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1954: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000032a93e9f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032904dab 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x00000000329034d3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488432a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6526 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:42:17.477616 [ 69946 ] {ea198a62-1824-4e67-a0dd-fd63cf18fd46} TCPHandler: Code: 36. DB::Exception: Replicated database requires 3 arguments: zookeeper path, shard name and replica name. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1954: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000032a93e9f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032904dab 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x00000000329034d3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488432a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6526 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:44:37.110035 [ 1271 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.117659 [ 1274 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.130964 [ 1268 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.165558 [ 1264 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.176752 [ 1278 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.184070 [ 1279 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.693383 [ 1277 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.891315 [ 1273 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.931346 [ 1275 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.944506 [ 1269 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.969708 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_5_5_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.976216 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.976851 [ 1279 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_5_5_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.985780 [ 1278 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:37.995879 [ 1271 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.007857 [ 1274 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_5_5_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.021022 [ 1276 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.038764 [ 1275 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_3_3_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.064540 [ 1265 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_5_5_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.081937 [ 1273 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.097451 [ 1277 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_5_5_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.108308 [ 1269 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.109566 [ 1276 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.117316 [ 1278 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.130581 [ 1279 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_5_5_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.139486 [ 1271 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.140300 [ 1268 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.727959 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.772680 [ 1268 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.799125 [ 1279 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.799531 [ 1265 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.800261 [ 1277 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.801617 [ 1272 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:38.802016 [ 1266 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.120331 [ 1278 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.120331 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.412898 [ 1273 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.422634 [ 1265 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.437948 [ 1275 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.473407 [ 1269 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.526205 [ 1271 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.557892 [ 1268 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.581561 [ 1272 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.601175 [ 1270 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.601803 [ 1267 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.646333 [ 1275 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.646902 [ 1277 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.674550 [ 1279 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.682658 [ 1266 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.691563 [ 1276 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.702726 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.731764 [ 1264 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.739164 [ 1277 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.744045 [ 1273 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.770920 [ 1272 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_6_6_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:39.802980 [ 1266 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:40.498007 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:40.506260 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:40.530242 [ 1278 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:40.851664 [ 1273 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.011596 [ 1267 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.011932 [ 1266 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.021038 [ 1270 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.025227 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.115196 [ 1275 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.133154 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.135651 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.144820 [ 1271 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.228338 [ 1276 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.234500 [ 1265 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.243329 [ 1270 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.242678 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.316728 [ 1266 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:41.319634 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:42.707538 [ 1267 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_22_22_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:42.710155 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_22_22_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:42.843451 [ 1273 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_22_22_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:42.847086 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_22_22_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:42.908774 [ 1270 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_22_22_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:42.916363 [ 1279 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_22_22_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:43.187300 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_23_23_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.323660 [ 1269 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.338696 [ 1270 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.427523 [ 1264 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.428047 [ 1278 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.428046 [ 1266 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_29_29_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.431051 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_29_29_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.961731 [ 1271 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.974644 [ 1276 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_29_29_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.976167 [ 1269 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_29_29_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.985041 [ 1275 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_29_29_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:44.997797 [ 1279 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:45.046468 [ 1264 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:45.081307 [ 1265 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:45.121909 [ 1277 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_28_28_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:45.929343 [ 1266 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:45.931221 [ 1270 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:45.931246 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.089330 [ 1277 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.095965 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.096043 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.101460 [ 1272 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.103057 [ 1269 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.329014 [ 1268 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.332095 [ 1270 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.533828 [ 1279 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_36_36_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.541894 [ 1275 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.542776 [ 1267 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.550805 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.551288 [ 1271 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.557063 [ 1274 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_36_36_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.561462 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.616127 [ 1273 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.618223 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.661387 [ 1267 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.663585 [ 1266 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.730504 [ 1278 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_37_37_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.744293 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.758562 [ 1268 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.785389 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.827379 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_37_37_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.833307 [ 1275 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_37_37_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.833642 [ 1269 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_35_35_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.842575 [ 1270 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_37_37_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:46.846817 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_37_37_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:47.467603 [ 1264 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:47.471470 [ 1274 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:47.762553 [ 1266 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:47.762712 [ 1278 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_41_41_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:47.771549 [ 1272 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:47.772991 [ 1267 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_41_41_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.094419 [ 1265 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.101735 [ 1279 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_41_41_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.118143 [ 1268 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_41_41_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.138623 [ 1274 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.197334 [ 1276 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_41_41_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.211467 [ 1271 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.252881 [ 1270 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.262963 [ 1268 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_40_40_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.274791 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_41_41_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.282095 [ 1266 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_41_41_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.351323 [ 1272 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_43_43_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.402433 [ 1264 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_43_43_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.430798 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_43_43_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.458971 [ 1274 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_43_43_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.498677 [ 1267 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_43_43_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.559435 [ 1273 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_43_43_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.904413 [ 1279 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.908182 [ 1268 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.915165 [ 1267 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:48.916059 [ 1275 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.047938 [ 1269 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.081446 [ 1266 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.119734 [ 1279 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.133809 [ 1264 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.356107 [ 1271 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.364816 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.430918 [ 1273 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.678942 [ 1278 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.678942 [ 1267 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.678942 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.874075 [ 1276 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_49_49_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.874075 [ 1274 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.875957 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:49.878416 [ 1266 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_45_45_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:50.045561 [ 1278 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:50.053450 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_49_49_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:50.055650 [ 1268 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_47_47_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:50.071351 [ 1270 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:50.116262 [ 1276 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.013626 [ 1277 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_53_53_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.013656 [ 1272 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_53_53_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.327953 [ 1265 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.339761 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_53_53_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.351095 [ 1271 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_53_53_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.435470 [ 1278 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_53_53_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.437127 [ 1269 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_55_55_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.444176 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.454058 [ 1266 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_53_53_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.602620 [ 1268 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr2&part=all_53_53_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.905618 [ 1277 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.935185 [ 1266 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_52_52_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.949066 [ 1271 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.984920 [ 1276 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.987217 [ 1275 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_55_55_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:51.997666 [ 1277 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_55_55_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.015812 [ 1264 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_55_55_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.018286 [ 1272 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_55_55_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.031235 [ 1273 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.412489 [ 1264 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.418160 [ 1272 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.424037 [ 1279 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.502353 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.538888 [ 1278 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.540663 [ 1272 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.664003 [ 1267 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.664281 [ 1270 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.668986 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.670797 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.670838 [ 1265 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.976202 [ 1275 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:52.995491 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.019877 [ 1278 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.019877 [ 1279 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.019879 [ 1269 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.029692 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.030188 [ 1274 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.063115 [ 1266 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.067032 [ 1278 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.071068 [ 1265 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.087538 [ 1268 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.100698 [ 1279 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.119757 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.139590 [ 1266 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.161222 [ 1275 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr4&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.161222 [ 1270 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.383667 [ 1264 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.466010 [ 1271 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.467922 [ 1273 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.470058 [ 1269 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_57_57_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.486118 [ 1276 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.493076 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.546863 [ 1265 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.567086 [ 1272 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.664209 [ 1279 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.682852 [ 1272 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.692251 [ 1273 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:53.770746 [ 1279 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_59_59_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:54.548843 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:54.548843 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:54.607269 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:54.608414 [ 1276 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:54.674865 [ 1272 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:54.783812 [ 1266 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.086421 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.089227 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.202673 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr3&part=all_66_66_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.292748 [ 1272 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_67_67_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.293742 [ 1268 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.306935 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_67_67_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.332428 [ 1267 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_65_65_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.364957 [ 1265 ] {} test_3ji3ptpv.r1 (dc3d4905-34b2-45d2-9c79-13d31b62e0db): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_69_69_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.371269 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_69_69_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.375403 [ 1269 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.394842 [ 1274 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_67_67_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.409865 [ 1273 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_69_69_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.439452 [ 1267 ] {} test_3ji3ptpv.r2 (51a415df-23d9-426e-8cee-b104ddd33f41): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_67_67_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.658037 [ 1267 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_69_69_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:55.877658 [ 1279 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr5&part=all_69_69_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:56.082203 [ 1272 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_69_69_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:56.168288 [ 1265 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:56.171169 [ 1273 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:56.174269 [ 1268 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:56.240239 [ 1271 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:56.834535 [ 1270 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:57.076366 [ 1276 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:57.177084 [ 1267 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:57.497674 [ 1278 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:57.687110 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:57.936514 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:58.024407 [ 1279 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:58.177392 [ 1266 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:58.215783 [ 1272 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:58.751647 [ 1269 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:58.850233 [ 1267 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.031874 [ 1278 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.296894 [ 1273 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.428105 [ 1277 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.492538 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.495151 [ 1275 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.637911 [ 1270 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.673858 [ 1276 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.693770 [ 1274 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:44:59.993355 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:00.055591 [ 1264 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:00.099336 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:00.430841 [ 1271 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:00.537572 [ 1266 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:00.886631 [ 1270 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:01.005987 [ 1276 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:01.324698 [ 1267 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:01.665881 [ 1265 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:01.689169 [ 1278 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:01.879371 [ 1277 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:01.954035 [ 1271 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:02.471621 [ 1275 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:02.563114 [ 1272 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:02.676278 [ 1276 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:03.370408 [ 1267 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:03.450306 [ 1265 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:03.627624 [ 1264 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:04.255294 [ 1268 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:04.317434 [ 1279 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:04.417642 [ 1266 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:04.622877 [ 1270 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:04.963720 [ 1276 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:05.299160 [ 1274 ] {} test_3ji3ptpv.r4 (7a8e3647-a633-4faf-a162-2e7583a16921): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:05.392595 [ 1265 ] {} test_3ji3ptpv.r3 (ebeaa37d-e9c7-442d-8ae3-b6abb46144d7): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:05.406712 [ 1273 ] {} test_3ji3ptpv.r5 (7c7cda3c-8f62-458e-a435-7fbeb45ab540): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://a3f64dc0082a:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_3ji3ptpv%2Fr%2Freplicas%2Fr1&part=all_73_73_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10063.altinitytest (altinity build)). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020977a43 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020977487 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb144c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb1915 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb35f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bba761 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bac33f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb6e3c 11. DB::ReadBuffer::next() @ 0x00000000095b2aaf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb051a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9f146 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003936d61f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038a9601d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000038815b9c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000387ed6b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387a8e43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a8ee90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a11f9ec 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038885c55 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038a90a39 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0a9d7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396875b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039689299 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396985df 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:42.519761 [ 1239 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (26.16 GiB) 2025.06.18 11:45:42.520553 [ 1239 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (24.79 GiB) 2025.06.18 11:45:43.265332 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c126b58e-f6ef-4f00-bc1f-33b2c899726b::202506_1_326_145}: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 27.77 GiB (attempt to allocate chunk of 2068542 bytes), maximum: 27.54 GiB. OvercommitTracker decision: Memory overcommit isn't used. Waiting time or overcommit denominator are set to zero. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff751c4 10. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x0000000031948e3f 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:49: DB::CompressedWriteBuffer::nextImpl() @ 0x00000000320e0e6c 12. ./src/IO/WriteBuffer.h:66: DB::HashingWriteBuffer::nextImpl() @ 0x0000000039397c02 13. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083d8ce5 14. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:142: DB::SerializationString::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000003282c304 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000032635569 16. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x00000000327613cc 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::SerializationTuple::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000032857af2 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003265b350 19. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:439: DB::SerializationMap::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003275f2d1 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeDataPartWriterWide::writeSingleGranule(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::shared_ptr&, DB::ISerialization::SerializeBinaryBulkSettings&, DB::Granule const&) @ 0x00000000399ee730 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:0: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x00000000399eb1e6 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:0: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000399e5c8b 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:368: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x0000000039e1f629 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x00000000396207d5 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039620080 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039635140 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a361d 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:45:43.491714 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e5ad1935-1920-48d0-a0c0-5bcdc1c6a390::202506_463_552_37}: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 27.76 GiB (attempt to allocate chunk of 1760854 bytes), maximum: 27.54 GiB. OvercommitTracker decision: Memory overcommit isn't used. Waiting time or overcommit denominator are set to zero. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff751c4 10. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000002018630a 11. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x00000000202038f3 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000002020190d 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x0000000020590488 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x0000000032ec4223 15. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032eac918 16. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x0000000032eff863 17. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000393a9b91 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:141: DB::IMergeTreeDataPart::MinMaxIndex::store(std::vector> const&, std::vector, std::allocator>> const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x0000000039441172 19. ./contrib/llvm-project/libcxx/include/vector:438: DB::IMergeTreeDataPart::MinMaxIndex::store(DB::MergeTreeData const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x000000003943fca9 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000039e27849 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e22da2 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePart(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e204b6 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::MergeProjectionsStage::finalizeProjectionsAndWholeMerge() const @ 0x000000003963622f 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1020: DB::MergeTask::MergeProjectionsStage::execute() @ 0x0000000039636c60 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039635140 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a361d 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:47:54.877252 [ 72152 ] {2cc7492b-a583-4074-8b87-113a64165471} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack UUID into column with type Int32.: (in file/uri /var/lib/clickhouse/user_files/02422_data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54340) (comment: 02422_msgpack_uuid_wrong_column.sql) (in query: select * from file(02422_data.msgpack, auto, 'x Int32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:338: DB::insertUUID(DB::IColumn&, std::shared_ptr, char const*, unsigned long) @ 0x000000003b29517d 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:486: DB::MsgPackVisitor::visit_ext(char const*, unsigned int) @ 0x000000003b29389c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c8b53 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:47:54.883316 [ 72152 ] {2cc7492b-a583-4074-8b87-113a64165471} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack UUID into column with type Int32.: (in file/uri /var/lib/clickhouse/user_files/02422_data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:338: DB::insertUUID(DB::IColumn&, std::shared_ptr, char const*, unsigned long) @ 0x000000003b29517d 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:486: DB::MsgPackVisitor::visit_ext(char const*, unsigned int) @ 0x000000003b29389c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2c8b53 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b29f36a 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b296088 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:07.570517 [ 72152 ] {054f71c6-0ec5-456d-a40f-d1561bac3235} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43588) (comment: 02411_merge_tree_zero_max_read_buffer_size.sql) (in query: SELECT * FROM data_02411 FORMAT Null SETTINGS max_read_buffer_size=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d2a0a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337aaad6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003bec9bdd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a5d37b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a209f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a1ff33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2ce816 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:07.574068 [ 72152 ] {054f71c6-0ec5-456d-a40f-d1561bac3235} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d2a0a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337aaad6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003bec9bdd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a5d37b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a209f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a1ff33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2ce816 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6f902 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d56534 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 24. ? @ 0x00007f8e6ce63ac3 25. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:15.882838 [ 72152 ] {fc7bc216-9e95-4e22-9fbd-586e170a784a} executeQuery: std::exception. Code: 1001, type: avro::Exception, e.what() = Cannot read compressed data, expected at least 4 bytes, got 0 (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:36050) (comment: 02373_heap_buffer_overflow_in_avro.sh) (in query: select * from file(corrupted.avro)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(String const&) @ 0x0000000047c5f3e3 1. ./contrib/avro/lang/c++/api/Exception.hh:37: avro::DataFileReaderBase::readDataBlock() @ 0x0000000043919712 2. ./build_docker/./contrib/avro/lang/c++/impl/DataFile.cc:347: avro::DataFileReaderBase::hasMore() @ 0x000000004391a85b 3. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:0: DB::AvroRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003afb96c4 4. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:15.893882 [ 72152 ] {fc7bc216-9e95-4e22-9fbd-586e170a784a} TCPHandler: Code: 1001. DB::Exception: avro::Exception: Cannot read compressed data, expected at least 4 bytes, got 0. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(String const&) @ 0x0000000047c5f3e3 1. ./contrib/avro/lang/c++/api/Exception.hh:37: avro::DataFileReaderBase::readDataBlock() @ 0x0000000043919712 2. ./build_docker/./contrib/avro/lang/c++/impl/DataFile.cc:347: avro::DataFileReaderBase::hasMore() @ 0x000000004391a85b 3. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:0: DB::AvroRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003afb96c4 4. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038ed3 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:23.991754 [ 71108 ] {f62ff0cf-8bf8-4651-aa80-06c08d1d127a} executeQuery: Code: 497. DB::Exception: u_02311: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(path, name, value) ON system.zookeeper. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58744) (in query: insert into system.zookeeper (path, name, value) values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba6d9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:23.994857 [ 71108 ] {f62ff0cf-8bf8-4651-aa80-06c08d1d127a} TCPHandler: Code: 497. DB::Exception: u_02311: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(path, name, value) ON system.zookeeper. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba6d9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:29.845709 [ 71108 ] {1a1f935a-fe0d-430e-8604-ff499615f323} executeQuery: Code: 117. DB::Exception: Unknown field found in format header: 'y' at position 1 Set the 'input_format_skip_unknown_fields' parameter explicitly to ignore and proceed: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (INCORRECT_DATA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58802) (comment: 02286_mysql_dump_input_format.sh) (in query: select * from file(dump1.sql, MySQLDump, 'x Nullable(Int32), z String') order by x, z settings input_format_skip_unknown_fields = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/Formats/ColumnMapping.cpp:38: DB::ColumnMapping::addColumns(std::vector> const&, google::dense_hash_map, google::libc_allocator_with_realloc>> const&, DB::FormatSettings const&) @ 0x000000003b0b9fa7 5. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:360: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000003b2d8851 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038761 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:29.856521 [ 71108 ] {1a1f935a-fe0d-430e-8604-ff499615f323} TCPHandler: Code: 117. DB::Exception: Unknown field found in format header: 'y' at position 1 Set the 'input_format_skip_unknown_fields' parameter explicitly to ignore and proceed: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000b5dfc8d 4. ./build_docker/./src/Formats/ColumnMapping.cpp:38: DB::ColumnMapping::addColumns(std::vector> const&, google::dense_hash_map, google::libc_allocator_with_realloc>> const&, DB::FormatSettings const&) @ 0x000000003b0b9fa7 5. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:360: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000003b2d8851 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038761 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:36.515963 [ 71108 ] {b57e6186-c3fd-43b9-b093-e06513909de3} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a MySQLDump format file. Error: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file. (EMPTY_DATA_PASSED) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/dump1.sql). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51776) (comment: 02286_mysql_dump_input_format.sh) (in query: desc file(dump1.sql, MySQLDump) settings input_format_mysql_dump_table_name='test 3'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad96ec7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038306112 7. ./src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383079cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe36a40 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359dd741 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359daa65 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:36.522560 [ 71108 ] {b57e6186-c3fd-43b9-b093-e06513909de3} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a MySQLDump format file. Error: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file. (EMPTY_DATA_PASSED) (version 24.8.14.10063.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/dump1.sql). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beaebad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad96ec7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9b655 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038306112 7. ./src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383079cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe36a40 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359dd741 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359daa65 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:38.069877 [ 71108 ] {aa76f979-2e6b-43e9-a62e-91e3ed69da71} executeQuery: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (EMPTY_DATA_PASSED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51782) (comment: 02286_mysql_dump_input_format.sh) (in query: select * from file(dump1.sql, MySQLDump, 'x Nullable(Int32)') settings input_format_mysql_dump_table_name='test 3'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:347: DB::readFirstCreateAndInsertQueries(DB::ReadBuffer&, String&, DB::NamesAndTypesList&, std::vector>&) @ 0x000000003b2da298 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000003b2d8786 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038761 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:48:38.078092 [ 71108 ] {aa76f979-2e6b-43e9-a62e-91e3ed69da71} TCPHandler: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (EMPTY_DATA_PASSED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:347: DB::readFirstCreateAndInsertQueries(DB::ReadBuffer&, String&, DB::NamesAndTypesList&, std::vector>&) @ 0x000000003b2da298 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000003b2d8786 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b038761 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aecfa39 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831f257 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:26.508670 [ 71108 ] {1c6d859c-9697-4f1e-8321-64bc09504b2f} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33390) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:26.514596 [ 71108 ] {1c6d859c-9697-4f1e-8321-64bc09504b2f} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:27.373825 [ 73121 ] {24c140b9-7242-4ead-90bc-747cfcaac641} executeQuery: Code: 497. DB::Exception: test_user_02242: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(user) ON system.session_log. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33422) (comment: 02242_delete_user_race.sh) (in query: SELECT COUNT(*) FROM system.session_log WHERE user == 'test_user_02242'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d51c3e 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:27.379993 [ 73121 ] {24c140b9-7242-4ead-90bc-747cfcaac641} TCPHandler: Code: 497. DB::Exception: test_user_02242: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(user) ON system.session_log. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d51c3e 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:27.570433 [ 71108 ] {14c64953-af65-4bde-9837-b6a030e3493d} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33440) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:27.576342 [ 71108 ] {14c64953-af65-4bde-9837-b6a030e3493d} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:28.893425 [ 73121 ] {14e49554-11ec-437d-936d-99fc9f6307f3} executeQuery: Code: 512. DB::Exception: Role should be granted to set default. (SET_NON_GRANTED_ROLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33474) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:67: DB::InterpreterSetRoleQuery::updateUserSetDefaultRoles(DB::User&, DB::RolesOrUsersSet const&) @ 0x0000000036ea7b85 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:623: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000036ea8215 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000314c2a07 7. ./build_docker/./src/Access/AccessControl.cpp:568: DB::AccessControl::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x00000000311edf0f 8. ./build_docker/./src/Access/IAccessStorage.cpp:407: DB::IAccessStorage::update(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x00000000313fe9ed 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6a7b 10. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:28.900028 [ 73121 ] {14e49554-11ec-437d-936d-99fc9f6307f3} TCPHandler: Code: 512. DB::Exception: Role should be granted to set default. (SET_NON_GRANTED_ROLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:67: DB::InterpreterSetRoleQuery::updateUserSetDefaultRoles(DB::User&, DB::RolesOrUsersSet const&) @ 0x0000000036ea7b85 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:623: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000036ea8215 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000314c2a07 7. ./build_docker/./src/Access/AccessControl.cpp:568: DB::AccessControl::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x00000000311edf0f 8. ./build_docker/./src/Access/IAccessStorage.cpp:407: DB::IAccessStorage::update(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x00000000313fe9ed 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6a7b 10. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:29.002636 [ 71108 ] {92d1acfe-a174-4ce0-90f3-7bf01aa5f863} executeQuery: Code: 497. DB::Exception: test_user_02242: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(user) ON system.session_log. (ACCESS_DENIED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33490) (comment: 02242_delete_user_race.sh) (in query: SELECT COUNT(*) FROM system.session_log WHERE user == 'test_user_02242'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d51c3e 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:29.008975 [ 71108 ] {92d1acfe-a174-4ce0-90f3-7bf01aa5f863} TCPHandler: Code: 497. DB::Exception: test_user_02242: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(user) ON system.session_log. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312ea8ea 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312ea2a8 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e8d6e 6. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000031293103 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b9e42 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000033729923 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d51c3e 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfad7e 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cecd52 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce5612 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a3131 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:29.935639 [ 73121 ] {42e13f80-aa96-4277-9bc0-39ee13c14ffd} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33524) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:29.940654 [ 73121 ] {42e13f80-aa96-4277-9bc0-39ee13c14ffd} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:31.398034 [ 73121 ] {b8968a32-9d63-44ac-8f36-8ee93579e0e9} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:33560) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:31.402999 [ 73121 ] {b8968a32-9d63-44ac-8f36-8ee93579e0e9} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:32.201177 [ 71108 ] {} ServerErrorHandler: Code: 516. DB::Exception: test_user_02242: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311eebe1 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035083d2f 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035082969 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x000000003abc3f9f 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abab184 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:50:32.246631 [ 73121 ] {b0d67f47-3e3e-431f-9aca-76276f0dc7c3} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50722) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:32.251466 [ 73121 ] {b0d67f47-3e3e-431f-9aca-76276f0dc7c3} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:33.235681 [ 73121 ] {4b2064d8-1d2a-4fd2-82bb-f1f2bdc02cdd} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50776) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:33.240778 [ 73121 ] {4b2064d8-1d2a-4fd2-82bb-f1f2bdc02cdd} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:33.444908 [ 71108 ] {} ServerErrorHandler: Code: 516. DB::Exception: test_user_02242: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311eebe1 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035083d2f 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035082969 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x000000003abc3f9f 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abab184 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:50:34.175814 [ 71108 ] {b6f48410-bfa6-4492-bdb8-8d25711ac47b} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50796) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:34.180801 [ 71108 ] {b6f48410-bfa6-4492-bdb8-8d25711ac47b} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:34.807853 [ 71108 ] {} ServerErrorHandler: Code: 516. DB::Exception: test_user_02242: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311eebe1 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035083d2f 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035082969 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x000000003abc3f9f 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abab184 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:50:35.614171 [ 71108 ] {3a1a9918-290d-4393-b457-6fbd7273f673} executeQuery: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50826) (comment: 02242_delete_user_race.sh) (in query: SET DEFAULT ROLE test_role_02242 TO test_user_02242), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:35.620285 [ 71108 ] {3a1a9918-290d-4393-b457-6fbd7273f673} TCPHandler: Code: 192. DB::Exception: There is no user `test_user_02242` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Access/RolesOrUsersSet.cpp:0: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x00000000315690c6 6. ./build_docker/./src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x00000000315678a2 7. ./build_docker/./src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x0000000031568bf1 8. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:46: DB::InterpreterSetRoleQuery::setDefaultRole(DB::ASTSetRoleQuery const&) @ 0x0000000036ea6785 9. ./build_docker/./src/Interpreters/Access/InterpreterSetRoleQuery.cpp:0: DB::InterpreterSetRoleQuery::execute() @ 0x0000000036ea616b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:50:35.625436 [ 71108 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:50826, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:51:31.506185 [ 71108 ] {ff5c00ef-87f6-4e16-aed6-d4852613b771} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47108) (comment: 02155_multiple_inserts_for_formats_with_suffix.sql) (in query: insert into test select * from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:31.509524 [ 71108 ] {ff5c00ef-87f6-4e16-aed6-d4852613b771} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:31.997134 [ 71108 ] {99c3575a-957d-45bd-9d07-c04307e896dd} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47108) (comment: 02155_multiple_inserts_for_formats_with_suffix.sql) (in query: insert into test select * from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:31.999869 [ 71108 ] {99c3575a-957d-45bd-9d07-c04307e896dd} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:32.438214 [ 71108 ] {5c4f7d62-ae7d-497c-a473-96ffc3e50d96} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47108) (comment: 02155_multiple_inserts_for_formats_with_suffix.sql) (in query: insert into table function file(concat(currentDatabase(), '/test2/data.Parquet'), 'Parquet', 'number UInt64') select * from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:32.440969 [ 71108 ] {5c4f7d62-ae7d-497c-a473-96ffc3e50d96} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:32.957580 [ 71108 ] {72072312-2aae-4462-b9a7-99d8705a7188} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47108) (comment: 02155_multiple_inserts_for_formats_with_suffix.sql) (in query: insert into test select * from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:32.961152 [ 71108 ] {72072312-2aae-4462-b9a7-99d8705a7188} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:33.436823 [ 71108 ] {1afe4004-4e6e-4cd7-9a01-3d8e86b9137c} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:47108) (comment: 02155_multiple_inserts_for_formats_with_suffix.sql) (in query: insert into table function file(concat(currentDatabase(), '/test4/data.Parquet.gz'), 'Parquet', 'number UInt64') select * from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:51:33.439643 [ 71108 ] {1afe4004-4e6e-4cd7-9a01-3d8e86b9137c} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832e897 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba7448f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034b94dc1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b97dcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9e560 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba776c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:04.960499 [ 73862 ] {312afceb-42f8-4f8f-bfc1-33bcdada51d1} executeQuery: Code: 60. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60224) (comment: 01850_dist_INSERT_preserve_error.sql) (in query: INSERT INTO data_01850 (key) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b910db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a4914 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:04.964253 [ 73862 ] {312afceb-42f8-4f8f-bfc1-33bcdada51d1} TCPHandler: Code: 60. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b910db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a4914 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:05.290835 [ 71108 ] {59d17a4f-7b71-4411-8933-44048b8a30c7} executeQuery: Code: 60. DB::Exception: Received from localhost:9000. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b910db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a4914 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 : Insertion status: Wrote 1 blocks and 1 rows on shard 0 replica 0, localhost:9000 (average 76 ms per block) Wrote 0 blocks and 0 rows on shard 0 replica 1, localhost:9000 (average 446 ms per block) . (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60204) (comment: 01850_dist_INSERT_preserve_error.sql) (in query: insert into dist_01850 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020198b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b950c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d4d1b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:62: DB::RemoteInserter::RemoteInserter(DB::Connection&, DB::ConnectionTimeouts const&, String const&, DB::Settings const&, DB::ClientInfo const&) @ 0x00000000392f1210 6. ./src/Processors/Sinks/RemoteSink.h:19: std::shared_ptr std::allocate_shared[abi:v15007], DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&, void>(std::allocator const&, DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&) @ 0x0000000039337ac3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003932f9e1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:05.298868 [ 71108 ] {59d17a4f-7b71-4411-8933-44048b8a30c7} TCPHandler: Code: 60. DB::Exception: Received from localhost:9000. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b910db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a4914 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 : Insertion status: Wrote 1 blocks and 1 rows on shard 0 replica 0, localhost:9000 (average 76 ms per block) Wrote 0 blocks and 0 rows on shard 0 replica 1, localhost:9000 (average 446 ms per block) . (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020198b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b950c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d4d1b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:62: DB::RemoteInserter::RemoteInserter(DB::Connection&, DB::ConnectionTimeouts const&, String const&, DB::Settings const&, DB::ClientInfo const&) @ 0x00000000392f1210 6. ./src/Processors/Sinks/RemoteSink.h:19: std::shared_ptr std::allocate_shared[abi:v15007], DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&, void>(std::allocator const&, DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&) @ 0x0000000039337ac3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003932f9e1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:05.795256 [ 71108 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./src/Common/Exception.h:0: _ZN2DB12NetExceptionC2IRA44_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000003ac0c456 3. ./build_docker/./src/Server/TCPHandler.cpp:2178: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x000000003abfbd04 4. ./build_docker/./src/Server/TCPHandler.cpp:1752: DB::TCPHandler::receivePacket() @ 0x000000003abca40c 5. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abacb25 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 12. ? @ 0x00007f8e6ce63ac3 13. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:45.761015 [ 71108 ] {e21dafca-8ceb-4d16-874f-38a8d41b13dd} executeQuery: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53610) (comment: 01603_rename_overwrite_bug.sql) (in query: rename table test_1603_rename_bug_ordinary.bar to test_1603_rename_bug_ordinary.foo;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000003294ea23 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000003294de29 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000032950ab6 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc5a11 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:45.764267 [ 71108 ] {e21dafca-8ceb-4d16-874f-38a8d41b13dd} TCPHandler: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000003294ea23 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000003294de29 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000032950ab6 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc5a11 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:46.733869 [ 71108 ] {e5497f74-415a-4750-a44d-b3861d786060} executeQuery: Code: 57. DB::Exception: Table `test_1603_rename_bug_atomic`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:53610) (comment: 01603_rename_overwrite_bug.sql) (in query: rename table test_1603_rename_bug_atomic.bar to test_1603_rename_bug_atomic.foo;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000003294ea23 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:0: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000003298a511 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc5a11 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:52:46.737195 [ 71108 ] {e5497f74-415a-4750-a44d-b3861d786060} TCPHandler: Code: 57. DB::Exception: Table `test_1603_rename_bug_atomic`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000003294ea23 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:0: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000003298a511 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc5a11 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:11.794080 [ 73121 ] {de2fa33f-7d4f-4133-962c-c94a8ad2b139} executeQuery: Code: 341. DB::Exception: Mutation 0000000000 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:57050) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_5 MODIFY COLUMN value UInt64 SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:11.800011 [ 73121 ] {de2fa33f-7d4f-4133-962c-c94a8ad2b139} TCPHandler: Code: 341. DB::Exception: Mutation 0000000000 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:14.312409 [ 71108 ] {ab1a9b43-6bfe-49b1-8891-fae2a7ab7d2a} executeQuery: Code: 341. DB::Exception: Mutation 0000000001 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49584) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_3 MODIFY COLUMN value String SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:14.318671 [ 71108 ] {ab1a9b43-6bfe-49b1-8891-fae2a7ab7d2a} TCPHandler: Code: 341. DB::Exception: Mutation 0000000001 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:16.835908 [ 71108 ] {b59fc57f-6c75-4cb5-88a9-9ec510379df0} executeQuery: Code: 341. DB::Exception: Mutation 0000000002 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49616) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_3 MODIFY COLUMN value UInt64 SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:16.845824 [ 71108 ] {b59fc57f-6c75-4cb5-88a9-9ec510379df0} TCPHandler: Code: 341. DB::Exception: Mutation 0000000002 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:19.312133 [ 71108 ] {934582da-60a0-45e7-a63e-45303afa4af9} executeQuery: Code: 341. DB::Exception: Mutation 0000000003 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49656) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_2 MODIFY COLUMN value String SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:19.318732 [ 71108 ] {934582da-60a0-45e7-a63e-45303afa4af9} TCPHandler: Code: 341. DB::Exception: Mutation 0000000003 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:21.832607 [ 71108 ] {08bb1486-1ad0-4cff-a14d-d1186e53b4e0} executeQuery: Code: 341. DB::Exception: Mutation 0000000004 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:49696) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_2 MODIFY COLUMN value UInt64 SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:21.838819 [ 71108 ] {08bb1486-1ad0-4cff-a14d-d1186e53b4e0} TCPHandler: Code: 341. DB::Exception: Mutation 0000000004 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:24.410544 [ 73121 ] {7d8ad277-8b5c-47d1-8dc9-09eac6035921} executeQuery: Code: 341. DB::Exception: Mutation 0000000005 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52782) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_4 MODIFY COLUMN value String SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:24.418655 [ 73121 ] {7d8ad277-8b5c-47d1-8dc9-09eac6035921} TCPHandler: Code: 341. DB::Exception: Mutation 0000000005 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:26.912744 [ 73121 ] {f59bae4e-f15f-41f0-8b68-c2f4c04d3862} executeQuery: Code: 341. DB::Exception: Mutation 0000000006 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52814) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_4 MODIFY COLUMN value UInt64 SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:26.918490 [ 73121 ] {f59bae4e-f15f-41f0-8b68-c2f4c04d3862} TCPHandler: Code: 341. DB::Exception: Mutation 0000000006 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:29.405231 [ 73121 ] {7b7cd806-29a9-44c6-b36f-fc17af9ff450} executeQuery: Code: 341. DB::Exception: Mutation 0000000007 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52856) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_5 MODIFY COLUMN value String SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:29.410426 [ 73121 ] {7b7cd806-29a9-44c6-b36f-fc17af9ff450} TCPHandler: Code: 341. DB::Exception: Mutation 0000000007 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:31.938974 [ 73121 ] {77c2c382-9882-4fce-ab64-408e298d9a60} executeQuery: Code: 341. DB::Exception: Mutation 0000000008 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52888) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_4 MODIFY COLUMN value UInt64 SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:31.945242 [ 73121 ] {77c2c382-9882-4fce-ab64-408e298d9a60} TCPHandler: Code: 341. DB::Exception: Mutation 0000000008 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:34.414032 [ 73121 ] {abcc58fe-3d0c-4a4e-bfb7-559e80721788} executeQuery: Code: 341. DB::Exception: Mutation 0000000009 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44340) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_4 MODIFY COLUMN value String SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:34.419785 [ 73121 ] {abcc58fe-3d0c-4a4e-bfb7-559e80721788} TCPHandler: Code: 341. DB::Exception: Mutation 0000000009 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:36.901391 [ 73121 ] {351c6dc7-ff3a-4fa5-bf68-56afa2ef5c9a} executeQuery: Code: 341. DB::Exception: Mutation 0000000010 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:44382) (comment: 01593_concurrent_alter_mutations_kill_many_replicas_long.sh) (in query: ALTER TABLE concurrent_kill_1 MODIFY COLUMN value UInt64 SETTINGS replication_alter_partitions_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:53:36.906951 [ 73121 ] {351c6dc7-ff3a-4fa5-bf68-56afa2ef5c9a} TCPHandler: Code: 341. DB::Exception: Mutation 0000000010 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:14.769538 [ 75034 ] {3a6319d1-b592-4b1e-8779-9812c572751e} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary database_for_dict.dict1 as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51394) (comment: 01575_disable_detach_table_of_dictionary.sql) (in query: DETACH TABLE database_for_dict.dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x0000000038243a94 5. ./build_docker/./src/Storages/StorageDictionary.cpp:160: DB::StorageDictionary::checkTableCanBeDetached() const @ 0x0000000038243bfa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492a75c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:14.772571 [ 75034 ] {3a6319d1-b592-4b1e-8779-9812c572751e} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary database_for_dict.dict1 as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x0000000038243a94 5. ./build_docker/./src/Storages/StorageDictionary.cpp:160: DB::StorageDictionary::checkTableCanBeDetached() const @ 0x0000000038243bfa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492a75c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:15.193618 [ 75034 ] {76ff09eb-43ca-4011-8557-9fd439414a56} executeQuery: Code: 80. DB::Exception: Cannot ATTACH TABLE database_for_dict.dict1, it is a Dictionary. (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51394) (comment: 01575_disable_detach_table_of_dictionary.sql) (in query: ATTACH TABLE database_for_dict.dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1282: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c1b9c 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:15.196826 [ 75034 ] {76ff09eb-43ca-4011-8557-9fd439414a56} TCPHandler: Code: 80. DB::Exception: Cannot ATTACH TABLE database_for_dict.dict1, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1282: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c1b9c 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.282185 [ 73121 ] {0f45970a-ba13-436b-989b-10e9411335a1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35502) (comment: 01459_manual_write_to_replicas_quorum_detach_attach.sh) (in query: INSERT INTO r3 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.282289 [ 71054 ] {569f9c86-022a-493c-ad1d-c69f79f86994} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35514) (comment: 01459_manual_write_to_replicas_quorum_detach_attach.sh) (in query: INSERT INTO r4 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.282185 [ 75386 ] {4db3fc2d-b23f-4d97-a322-45f260c964f2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35526) (comment: 01459_manual_write_to_replicas_quorum_detach_attach.sh) (in query: INSERT INTO r6 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.282460 [ 76223 ] {07952724-5743-4bfc-823d-92d777ef138e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35536) (comment: 01459_manual_write_to_replicas_quorum_detach_attach.sh) (in query: INSERT INTO r2 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.290705 [ 71054 ] {569f9c86-022a-493c-ad1d-c69f79f86994} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.290705 [ 75386 ] {4db3fc2d-b23f-4d97-a322-45f260c964f2} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.290705 [ 73121 ] {0f45970a-ba13-436b-989b-10e9411335a1} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:44.292528 [ 76223 ] {07952724-5743-4bfc-823d-92d777ef138e} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:54.836097 [ 75386 ] {006023cd-5200-4528-89ff-2ecfbcf54972} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:48572) (comment: 01459_manual_write_to_replicas_quorum_detach_attach.sh) (in query: INSERT INTO r1 SELECT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:54:54.844997 [ 75386 ] {006023cd-5200-4528-89ff-2ecfbcf54972} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 3 actual_number_of_replicas: 1 replicas: r5 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841f50a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a21cd33 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a217f7f 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a1e5cfe 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1de55f 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb268c4 9. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7ffee9 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7fe6a7 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:57:05.470918 [ 660 ] {} test_lvjvh22q.r7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/01459_manual_write_to_replicas_test_lvjvh22q/r/replicas/r1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003cba4bba 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbcd4b5 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0245e6 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a0203fc 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a01ce58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a045a3f 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:20.132841 [ 75386 ] {bdd399c2-d7bf-410a-949d-6664c435e724} executeQuery: Code: 341. DB::Exception: Mutation 0000000000 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56908) (comment: 01414_mutations_and_errors_zookeeper.sh) (in query: ALTER TABLE replicated_mutation_table UPDATE key = key + 1 WHERE sleepEachRow(3) == 0 SETTINGS mutations_sync = 2, function_sleep_max_microseconds_per_block=100000000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003899a288 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:57:20.138586 [ 75386 ] {bdd399c2-d7bf-410a-949d-6664c435e724} TCPHandler: Code: 341. DB::Exception: Mutation 0000000000 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387434f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003899a288 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348582d3 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:57:28.540994 [ 1252 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 30000000 microseconds per block (of size 10): while executing 'FUNCTION sleepEachRow(3 :: 1) -> sleepEachRow(3) UInt8 : 5'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff 23. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e50b26 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0037fe 25. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:28.541186 [ 1248 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 30000000 microseconds per block (of size 10): while executing 'FUNCTION sleepEachRow(3 :: 1) -> sleepEachRow(3) UInt8 : 5'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff 23. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e50b26 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0037fe 25. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:28.541438 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_2}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 30000000 microseconds per block (of size 10): while executing 'FUNCTION sleepEachRow(3 :: 1) -> sleepEachRow(3) UInt8 : 5'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff 23. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e50b26 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0037fe 25. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:28.541756 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_0_0_0_2}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 30000000 microseconds per block (of size 10): while executing 'FUNCTION sleepEachRow(3 :: 1) -> sleepEachRow(3) UInt8 : 5'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bde97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0bdadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bc251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff 23. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e50b26 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0037fe 25. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffff6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396908de 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396926a8 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396999bf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:28.564903 [ 1241 ] {} test_d615q5h2.replicated_mutation_table (ReplicatedMergeTreeQueue): Mutation with version 2 not found in partition ID 20191002 (trying to mutate part 20191002_1_1_0) 2025.06.18 11:57:28.565595 [ 1250 ] {} test_d615q5h2.replicated_mutation_table (ReplicatedMergeTreeQueue): Mutation with version 2 not found in partition ID 20191002 (trying to mutate part 20191002_0_0_0) 2025.06.18 11:57:29.647270 [ 1254 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:29.647969 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:30.286841 [ 1249 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:30.287644 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:30.569053 [ 1247 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:30.569675 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:31.610127 [ 1244 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:31.610786 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:32.141553 [ 1254 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:32.142247 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:32.332769 [ 1251 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:32.333589 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:33.278326 [ 1252 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:33.278929 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:33.866160 [ 1240 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:33.866721 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:34.227848 [ 1251 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:34.228383 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:35.358931 [ 1253 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:35.359505 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:36.495990 [ 1255 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:36.496578 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:36.999988 [ 1244 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:37.000536 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:37.377069 [ 1241 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:37.377659 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:37.886188 [ 1252 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:37.886759 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:38.392927 [ 1251 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:38.393478 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:38.606778 [ 1252 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:38.607326 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:38.984398 [ 1247 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:38.984968 [ 1247 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:39.684379 [ 1254 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:39.684974 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:40.761209 [ 1250 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:40.761797 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:41.430666 [ 1249 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:41.431216 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:41.898321 [ 1244 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:41.898902 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:42.703121 [ 1248 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:42.703715 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:42.946167 [ 1244 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:42.946728 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:43.347675 [ 1249 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:43.348340 [ 1249 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:43.616721 [ 1245 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:43.617260 [ 1245 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:44.643809 [ 1255 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:44.644582 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:45.593895 [ 1254 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:45.594466 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:45.793897 [ 1252 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:45.794433 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:46.656865 [ 1248 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:46.657413 [ 1248 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:47.312684 [ 1245 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:47.313865 [ 1245 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:47.831302 [ 1250 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:47.832053 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:48.110286 [ 1240 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:48.110856 [ 1240 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:48.800907 [ 1244 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:48.801529 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:49.032333 [ 1252 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:49.033117 [ 1252 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:50.079196 [ 1242 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:50.079770 [ 1242 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:50.897168 [ 1246 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:50.897745 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:51.721593 [ 1241 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:51.722160 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:52.800737 [ 1253 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:52.801383 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:53.950396 [ 1241 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:53.951080 [ 1241 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:54.990952 [ 1244 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:54.991736 [ 1244 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:55.611307 [ 1251 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:55.611892 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:56.768455 [ 1243 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:56.769028 [ 1243 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:57.441675 [ 1255 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:57.442232 [ 1255 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:58.251861 [ 1254 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:58.252402 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:59.257479 [ 1254 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:59.258089 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:59.770649 [ 1251 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:57:59.771190 [ 1251 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:00.299620 [ 1246 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:00.300189 [ 1246 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:01.456076 [ 1250 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:01.456712 [ 1250 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:02.013989 [ 76255 ] {0c95cf34-49b1-4985-9d0a-39f2aeb7af99} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation '0000000001' with part '20191002_1_1_0_2' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56918) (comment: 01414_mutations_and_errors_zookeeper.sh) (in query: ALTER TABLE replicated_mutation_table MODIFY COLUMN value UInt64 SETTINGS replication_alter_partitions_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfec9f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfea05 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x0000000038743c58 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:58:02.019031 [ 76255 ] {0c95cf34-49b1-4985-9d0a-39f2aeb7af99} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation '0000000001' with part '20191002_1_1_0_2' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfec9f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfea05 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x0000000038743c58 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000389250a1 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003891e148 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034857689 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 11:58:02.358859 [ 1254 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:02.359476 [ 1254 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:02.641987 [ 1253 ] {} b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:02.642564 [ 1253 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b64e489d-8bbe-469f-b315-f0c851e68116::20191002_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_2/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x0000000039cfbf22 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae46853 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aebd0a4 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5939b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed46c2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1781: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000039ed73e5 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e659ff (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:58:02.857787 [ 1254 ] {} test_d615q5h2.replicated_mutation_table (ReplicatedMergeTreeQueue): There are no mutations for partition ID 20191002 (trying to mutate part 20191002_1_1_0_2 to 3) 2025.06.18 11:58:05.599932 [ 76255 ] {edd9f778-3292-49e3-bd92-e98c95d9956a} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_3/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_PARSE_TEXT) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38264) (comment: 01414_mutations_and_errors_zookeeper.sh) (in query: SELECT distinct(value) FROM replicated_mutation_table ORDER BY value), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1065: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4272 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbb654 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 2025.06.18 11:58:05.612636 [ 76255 ] {edd9f778-3292-49e3-bd92-e98c95d9956a} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/b64/b64e489d-8bbe-469f-b315-f0c851e68116/20191002_1_1_0_3/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086e9802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088ac72a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008887c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d003f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000876a509 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086ceb34 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60027f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a1b16e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000035903c5e 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039c86687 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1065: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb4272 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2c006 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbb654 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1e150 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf600a5 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae45c9e 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 2025.06.18 11:58:56.377409 [ 75386 ] {4568d20e-1f4e-41b7-ace3-1b770927be94} test_xxf6fucn.test_table_1 (65ec84f5-0d2d-47f1-8a88-ae1989edc32a): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:58:56.380880 [ 75386 ] {4568d20e-1f4e-41b7-ace3-1b770927be94} test_xxf6fucn.test_table_1 (65ec84f5-0d2d-47f1-8a88-ae1989edc32a): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:58:58.336280 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:58:58.338063 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:58:58.376632 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:58:58.379820 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:58:58.393561 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:58:58.395474 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:58:58.408988 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:58:58.411021 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:58:58.424996 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:58:58.429244 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:58:58.442352 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:58:58.444862 [ 75386 ] {754464ca-82e5-434b-b237-2ca7a8e6db66} test_xxf6fucn.test_table_2 (f0c576d2-97af-4c85-9359-3e1e63ec0023): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:00.880130 [ 1059 ] {} test_xxf6fucn.test_table_1 (ReplicatedMergeTreeRestartingThread): Failed to restart the table. Will try again: Code: 415. DB::Exception: All replicas are lost. See SYSTEM DROP REPLICA and SYSTEM RESTORE REPLICA queries, they may help. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3535: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x0000000038880c11 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x000000003a19b061 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x000000003a197b50 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x000000003a1958f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a1b2fbf 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:59:00.880127 [ 973 ] {} test_xxf6fucn.test_table_2 (ReplicatedMergeTreeRestartingThread): Failed to restart the table. Will try again: Code: 415. DB::Exception: All replicas are lost. See SYSTEM DROP REPLICA and SYSTEM RESTORE REPLICA queries, they may help. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3535: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x0000000038880c11 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x000000003a19b061 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x000000003a197b50 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x000000003a1958f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a1b2fbf 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:59:00.881490 [ 973 ] {} test_xxf6fucn.test_table_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.18 11:59:00.881491 [ 963 ] {} test_xxf6fucn.test_table_1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.18 11:59:00.901480 [ 963 ] {} test_xxf6fucn.test_table_1 (ReplicatedMergeTreeRestartingThread): Failed to restart the table. Will try again: Code: 415. DB::Exception: All replicas are lost. See SYSTEM DROP REPLICA and SYSTEM RESTORE REPLICA queries, they may help. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3535: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x0000000038880c11 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x000000003a19b061 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x000000003a197b50 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x000000003a1958f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a1b2fbf 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:59:00.902632 [ 973 ] {} test_xxf6fucn.test_table_2 (ReplicatedMergeTreeRestartingThread): Failed to restart the table. Will try again: Code: 415. DB::Exception: All replicas are lost. See SYSTEM DROP REPLICA and SYSTEM RESTORE REPLICA queries, they may help. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3535: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x0000000038880c11 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x000000003a19b061 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x000000003a197b50 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x000000003a1958f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a1b2fbf 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:59:01.201469 [ 1032 ] {} test_xxf6fucn.test_table_1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.18 11:59:01.202588 [ 972 ] {} test_xxf6fucn.test_table_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.18 11:59:01.224153 [ 1032 ] {} test_xxf6fucn.test_table_1 (ReplicatedMergeTreeRestartingThread): Failed to restart the table. Will try again: Code: 415. DB::Exception: All replicas are lost. See SYSTEM DROP REPLICA and SYSTEM RESTORE REPLICA queries, they may help. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3535: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x0000000038880c11 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x000000003a19b061 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x000000003a197b50 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x000000003a1958f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a1b2fbf 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:59:01.225303 [ 972 ] {} test_xxf6fucn.test_table_2 (ReplicatedMergeTreeRestartingThread): Failed to restart the table. Will try again: Code: 415. DB::Exception: All replicas are lost. See SYSTEM DROP REPLICA and SYSTEM RESTORE REPLICA queries, they may help. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3535: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x0000000038880c11 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x000000003a19b061 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x000000003a197b50 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x000000003a1958f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a1b2fbf 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199aa12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a5d33 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a79cf 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:59:01.639476 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:01.642776 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:01.657212 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:01.659816 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:01.677804 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:01.680596 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:01.695690 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:01.697948 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:01.710770 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:01.713217 [ 75386 ] {bd04ae7c-2be1-43d1-83af-0190e8552d75} test_xxf6fucn.test_table_2 (89e1d9b5-5703-42e5-962d-66ec888f9bd2): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:02.754937 [ 75386 ] {4a10818b-88c6-44a5-aec7-11c5e7ab6434} test_xxf6fucn.test_table_1 (5c548218-5685-452c-abed-7d04e04bea35): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:02.757480 [ 75386 ] {4a10818b-88c6-44a5-aec7-11c5e7ab6434} test_xxf6fucn.test_table_1 (5c548218-5685-452c-abed-7d04e04bea35): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:02.768127 [ 75386 ] {4a10818b-88c6-44a5-aec7-11c5e7ab6434} test_xxf6fucn.test_table_1 (5c548218-5685-452c-abed-7d04e04bea35): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:02.769806 [ 75386 ] {4a10818b-88c6-44a5-aec7-11c5e7ab6434} test_xxf6fucn.test_table_1 (5c548218-5685-452c-abed-7d04e04bea35): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:03.742727 [ 75386 ] {28c99e83-7853-4fce-95fe-90894d772d63} test_xxf6fucn.test_table_2 (4c826f7c-eeb8-43d5-b599-d352be396c27): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:03.745058 [ 75386 ] {28c99e83-7853-4fce-95fe-90894d772d63} test_xxf6fucn.test_table_2 (4c826f7c-eeb8-43d5-b599-d352be396c27): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:03.756181 [ 75386 ] {28c99e83-7853-4fce-95fe-90894d772d63} test_xxf6fucn.test_table_2 (4c826f7c-eeb8-43d5-b599-d352be396c27): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:03.758535 [ 75386 ] {28c99e83-7853-4fce-95fe-90894d772d63} test_xxf6fucn.test_table_2 (4c826f7c-eeb8-43d5-b599-d352be396c27): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:04.774150 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} test_xxf6fucn.test_table_1 (8fd89c0e-58ae-4113-a432-1d81792b9951): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:04.776057 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} test_xxf6fucn.test_table_1 (8fd89c0e-58ae-4113-a432-1d81792b9951): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:04.788243 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} test_xxf6fucn.test_table_1 (8fd89c0e-58ae-4113-a432-1d81792b9951): Removing leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table (this might take several minutes) 2025.06.18 11:59:04.789941 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} test_xxf6fucn.test_table_1 (8fd89c0e-58ae-4113-a432-1d81792b9951): The leftovers from table /clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table were removed by another replica 2025.06.18 11:59:05.335978 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52738). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52738) (comment: 01305_replica_create_drop_zookeeper.sh) (in query: CREATE TABLE test_table_1 (`a` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01305_replica_create_drop_zookeeper_test_xxf6fucn/alter_table', 'r_1') ORDER BY tuple() SETTINGS index_granularity = 42159, min_bytes_for_wide_part = 744214609, ratio_of_defaults_for_sparse_serialization = 0.49034181237220764, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 18538030, compact_parts_max_bytes_to_buffer = 111760996, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 127387, merge_max_block_size = 18607, old_parts_lifetime = 339., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 26, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 24507336, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 8426, primary_key_compress_block_size = 58678), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003abd5bfe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaeec9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:05.339896 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52738). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 11:59:05.340482 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52738). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003abd5bfe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaeec9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 13. ? @ 0x00007f8e6ce63ac3 14. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:05.341586 [ 75386 ] {db5badb2-2bde-4354-96bd-1d84b700c1e7} TCPHandler: Client has gone away. 2025.06.18 11:59:19.431780 [ 73311 ] {ecc1a90b-9516-4934-8257-5eb3c4342608} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.00 GiB (attempt to allocate chunk of 134217728 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:52758) (comment: 01301_aggregate_state_exception_memory_leak.sh) (in query: SELECT uniqExactState(number) FROM system.numbers_mt GROUP BY number % 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff77d29 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x000000002e0dd2cc 9. ./src/Common/HashTable/HashTable.h:0: DB::IAggregateFunctionHelper>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2df676 10. ./src/AggregateFunctions/IAggregateFunction.h:751: DB::IAggregateFunctionDataHelper, DB::AggregateFunctionUniq>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2dc880 11. ./build_docker/./src/Interpreters/Aggregator.cpp:968: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034012c19 12. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401054a 13. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d5a3fc 14. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4febb 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d827 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 17. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:19.561971 [ 73311 ] {ecc1a90b-9516-4934-8257-5eb3c4342608} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.00 GiB (attempt to allocate chunk of 134217728 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff77d29 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x000000002e0dd2cc 9. ./src/Common/HashTable/HashTable.h:0: DB::IAggregateFunctionHelper>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2df676 10. ./src/AggregateFunctions/IAggregateFunction.h:751: DB::IAggregateFunctionDataHelper, DB::AggregateFunctionUniq>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2dc880 11. ./build_docker/./src/Interpreters/Aggregator.cpp:968: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034012c19 12. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401054a 13. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d5a3fc 14. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4febb 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d827 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 17. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:29.468773 [ 73311 ] {34395f4e-62dc-40e0-aaaa-61a5d8a02205} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.00 GiB (attempt to allocate chunk of 134217728 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:34400) (comment: 01301_aggregate_state_exception_memory_leak.sh) (in query: SELECT uniqExactState(number) FROM system.numbers_mt GROUP BY number % 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff77d29 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x000000002e0dd2cc 9. ./src/Common/HashTable/HashTable.h:0: DB::IAggregateFunctionHelper>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2df676 10. ./src/AggregateFunctions/IAggregateFunction.h:751: DB::IAggregateFunctionDataHelper, DB::AggregateFunctionUniq>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2dc880 11. ./build_docker/./src/Interpreters/Aggregator.cpp:968: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034012c19 12. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401054a 13. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d5a3fc 14. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4febb 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d827 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 17. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:29.624450 [ 73311 ] {34395f4e-62dc-40e0-aaaa-61a5d8a02205} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.00 GiB (attempt to allocate chunk of 134217728 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff77d29 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x000000002e0dd2cc 9. ./src/Common/HashTable/HashTable.h:0: DB::IAggregateFunctionHelper>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2df676 10. ./src/AggregateFunctions/IAggregateFunction.h:751: DB::IAggregateFunctionDataHelper, DB::AggregateFunctionUniq>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2dc880 11. ./build_docker/./src/Interpreters/Aggregator.cpp:968: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034012c19 12. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401054a 13. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d5a3fc 14. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4febb 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d827 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 17. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:39.551086 [ 73311 ] {965989e1-1658-4a52-b97b-dcbd56432a01} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.00 GiB (attempt to allocate chunk of 134217728 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37462) (comment: 01301_aggregate_state_exception_memory_leak.sh) (in query: SELECT uniqExactState(number) FROM system.numbers_mt GROUP BY number % 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff77d29 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x000000002e0dd2cc 9. ./src/Common/HashTable/HashTable.h:0: DB::IAggregateFunctionHelper>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2df676 10. ./src/AggregateFunctions/IAggregateFunction.h:751: DB::IAggregateFunctionDataHelper, DB::AggregateFunctionUniq>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2dc880 11. ./build_docker/./src/Interpreters/Aggregator.cpp:968: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034012c19 12. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401054a 13. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d5a3fc 14. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4febb 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d827 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 17. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:39.690150 [ 73311 ] {965989e1-1658-4a52-b97b-dcbd56432a01} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.00 GiB (attempt to allocate chunk of 134217728 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000200997b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020097a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020096e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7a63d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff77d29 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x000000002e0dd2cc 9. ./src/Common/HashTable/HashTable.h:0: DB::IAggregateFunctionHelper>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2df676 10. ./src/AggregateFunctions/IAggregateFunction.h:751: DB::IAggregateFunctionDataHelper, DB::AggregateFunctionUniq>>::addBatchLookupTable8(unsigned long, unsigned long, char**, unsigned long, std::function, char8_t const*, DB::IColumn const**, DB::Arena*) const @ 0x000000002e2dc880 11. ./build_docker/./src/Interpreters/Aggregator.cpp:968: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034012c19 12. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401054a 13. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d5a3fc 14. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4febb 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5d827 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b778a14 17. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b76c794 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:41.429551 [ 73311 ] {942aa694-3ba0-43cc-b6db-933db6c9c670} executeQuery: Code: 199. DB::Exception: There is no quota `q2_01297` in user directories. (UNKNOWN_QUOTA) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:45474) (comment: 01297_create_quota.sql) (in query: SHOW CREATE QUOTA q2_01297;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000036ec8d31 6. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000036ec5d35 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000036ec3b41 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000036ec3a04 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:41.431957 [ 73311 ] {942aa694-3ba0-43cc-b6db-933db6c9c670} TCPHandler: Code: 199. DB::Exception: There is no quota `q2_01297` in user directories. (UNKNOWN_QUOTA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f6c80 5. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000036ec8d31 6. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000036ec5d35 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000036ec3b41 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000036ec3a04 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:49.083901 [ 73311 ] {e318c04b-a213-408c-b71a-ba4c39c270a8} executeQuery: Code: 523. DB::Exception: There is no row policy `p2_01295 ON db.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:37744) (comment: 01295_create_row_policy.sql) (in query: SHOW CREATE ROW POLICY p2_01295 ON db.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./src/Access/IAccessStorage.h:0: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000036eca791 5. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000036ec5d35 6. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000036ec3b41 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000036ec3a04 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:49.086453 [ 73311 ] {e318c04b-a213-408c-b71a-ba4c39c270a8} TCPHandler: Code: 523. DB::Exception: There is no row policy `p2_01295 ON db.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f6eb0 4. ./src/Access/IAccessStorage.h:0: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000036eca791 5. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000036ec5d35 6. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000036ec3b41 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000036ec3a04 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:54.092920 [ 73311 ] {1dd1aa66-a325-4d30-b9f2-169247a12ec3} executeQuery: Code: 60. DB::Exception: Table test_f60w1b5a.table_that_do_not_exists does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54618) (comment: 01281_unsucceeded_insert_select_queries_counter.sql) (in query: -- Failed insert before execution INSERT INTO table_that_do_not_exists VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:54.095959 [ 73311 ] {1dd1aa66-a325-4d30-b9f2-169247a12ec3} TCPHandler: Code: 60. DB::Exception: Table test_f60w1b5a.table_that_do_not_exists does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8b76f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba64e8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 18. ? @ 0x00007f8e6ce63ac3 19. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:55.050451 [ 73311 ] {a545f860-3c2f-4f66-afcc-1e99d84737af} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54618) (comment: 01281_unsucceeded_insert_select_queries_counter.sql) (in query: -- Failed insert in execution INSERT INTO to_insert SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:55.060581 [ 73311 ] {a545f860-3c2f-4f66-afcc-1e99d84737af} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:55.292654 [ 73311 ] {148de376-cc74-4bb5-b12b-13e89192fd1b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'table_that_do_not_exists' in scope SELECT * FROM table_that_do_not_exists. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54618) (comment: 01281_unsucceeded_insert_select_queries_counter.sql) (in query: -- Failed select before execution SELECT * FROM table_that_do_not_exists;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:55.296848 [ 73311 ] {148de376-cc74-4bb5-b12b-13e89192fd1b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'table_that_do_not_exists' in scope SELECT * FROM table_that_do_not_exists. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:55.540963 [ 73311 ] {870b217b-3346-49ca-bf1f-b2b7190e1a24} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54618) (comment: 01281_unsucceeded_insert_select_queries_counter.sql) (in query: -- Failed select in execution SELECT throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 11:59:55.544976 [ 73311 ] {870b217b-3346-49ca-bf1f-b2b7190e1a24} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb981d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:00:05.607139 [ 24822 ] {7d34f107-fc1d-4fd1-ac7f-61359f8dee65} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:00:40.457324 [ 24958 ] {90bd58bc-e7d1-49e5-8bf7-9c843557787e} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:01:15.944697 [ 25121 ] {7bc524b4-2050-4818-8ea7-e07403255ff9} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:01:52.869570 [ 24911 ] {4556922a-62ab-47cc-a614-09c093f575b2} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:02:25.078740 [ 25575 ] {732f71ee-b951-4462-95ad-1071fd2c7026} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:03:00.030094 [ 25461 ] {9f4784d1-2520-48e3-a49a-3cb6e081fe10} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:03:34.468932 [ 25569 ] {fd3e0dda-b4e7-46cb-a495-c887230f10c2} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae79923 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae79388 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003ae76ed9 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 28. ? @ 0x00007f8e6ce63ac3 29. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:04:04.967781 [ 25661 ] {4c04fcc3-98b4-44b5-959a-498301a5a044} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_8ex42lq6.testXB (8a0ab8be-acc7-46ca-a891-5011a8adaab1). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c57279b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d17db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60009f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b605e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a15ffe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8019c4 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acc644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae3c5cb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7a544 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aebc7d2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba8465b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b80037b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7ff9f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7feb8b 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeac92d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7b866 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae7e078 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d5173 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e77a6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e755f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cdfdd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e0524 29. ? @ 0x00007f8e6ce63ac3 30. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:04:37.306414 [ 73311 ] {dc36130c-0d7f-4172-9e57-7fa5a0436fe5} executeQuery: Code: 487. DB::Exception: Dictionary `dict_db_01225.no_such_dict` doesn't exist. (CANNOT_GET_CREATE_DICTIONARY_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38278) (comment: 01225_show_create_table_from_dictionary.sql) (in query: SHOW CREATE TABLE dict_db_01225_dictionary.`dict_db_01225.no_such_dict`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Databases/DatabaseDictionary.cpp:104: DB::DatabaseDictionary::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032b4f01c 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359cdf4c 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359cd0c4 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:04:37.309826 [ 73311 ] {dc36130c-0d7f-4172-9e57-7fa5a0436fe5} TCPHandler: Code: 487. DB::Exception: Dictionary `dict_db_01225.no_such_dict` doesn't exist. (CANNOT_GET_CREATE_DICTIONARY_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Databases/DatabaseDictionary.cpp:104: DB::DatabaseDictionary::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032b4f01c 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359cdf4c 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359cd0c4 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:04:41.505465 [ 73311 ] {228b8eb2-5160-4138-8fa8-f35b83d57587} executeQuery: Code: 80. DB::Exception: Ordinary database engine does not support UUID. (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38298) (comment: 01192_rename_database_zookeeper.sh) (in query: CREATE DATABASE test_01192 UUID '00001192-0000-4000-8000-000000000001' ENGINE=Ordinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:267: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034888f16 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6526 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:04:41.508054 [ 73311 ] {228b8eb2-5160-4138-8fa8-f35b83d57587} TCPHandler: Code: 80. DB::Exception: Ordinary database engine does not support UUID. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:267: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034888f16 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6526 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:04:45.627775 [ 75386 ] {bdc86227-4510-4f30-a825-050902fb03ca} executeQuery: Code: 82. DB::Exception: Database default already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46214) (comment: 01192_rename_database_zookeeper.sh) (in query: RENAME DATABASE test_01192 TO default), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:538: DB::DatabaseCatalog::assertDatabaseDoesntExistUnlocked(String const&) const @ 0x000000003399b42e 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::assertDatabaseDoesntExist(String const&) const @ 0x000000003399b149 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bc2e89 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3aa 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 12:04:45.631600 [ 75386 ] {bdc86227-4510-4f30-a825-050902fb03ca} TCPHandler: Code: 82. DB::Exception: Database default already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:538: DB::DatabaseCatalog::assertDatabaseDoesntExistUnlocked(String const&) const @ 0x000000003399b42e 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::assertDatabaseDoesntExist(String const&) const @ 0x000000003399b149 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bc2e89 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3aa 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 2025.06.18 12:04:46.510685 [ 75386 ] {59fea0c0-5b46-4fa1-9b13-a82b511b39fb} executeQuery: Code: 81. DB::Exception: Database test_01192_notexisting does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46222) (comment: 01192_rename_database_zookeeper.sh) (in query: RENAME DATABASE test_01192_notexisting TO test_01192_renamed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:660: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339a137c 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:189: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bc2dfa 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3aa 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:04:46.513797 [ 75386 ] {59fea0c0-5b46-4fa1-9b13-a82b511b39fb} TCPHandler: Code: 81. DB::Exception: Database test_01192_notexisting does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:660: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339a137c 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:189: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bc2dfa 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3aa 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:05:09.017546 [ 73311 ] {49930b94-d2c7-45ac-bd30-0cd8438e48c1} executeQuery: Code: 60. DB::Exception: Table test_01192.rmt does not exist. Maybe you meant test_01192_atomic.rmt?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35044) (comment: 01192_rename_database_zookeeper.sh) (in query: SELECT count(n), sum(n) FROM test_01192_atomic.mv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::getTargetTable() const @ 0x0000000038568796 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038568b8b 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000335a2250 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dbdff 12. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 12:05:09.021604 [ 73311 ] {49930b94-d2c7-45ac-bd30-0cd8438e48c1} TCPHandler: Code: 60. DB::Exception: Table test_01192.rmt does not exist. Maybe you meant test_01192_atomic.rmt?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a7f41 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::getTargetTable() const @ 0x0000000038568796 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038568b8b 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000335a2250 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033476209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dbdff 12. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 30. ? @ 0x00007f8e6ce63ac3 31. ? @ 0x00007f8e6cef5850 2025.06.18 12:05:13.916659 [ 75386 ] {a3f07c95-a54c-4c42-a541-e719195b2985} executeQuery: Code: 48. DB::Exception: Ordinary: RENAME DATABASE is not supported. (NOT_IMPLEMENTED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60956) (comment: 01192_rename_database_zookeeper.sh) (in query: RENAME DATABASE test_01192 TO test_01192_renamed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IDatabase::renameDatabase(std::shared_ptr, String const&) @ 0x000000003291d486 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bc2f2a 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3aa 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:05:13.919175 [ 75386 ] {a3f07c95-a54c-4c42-a541-e719195b2985} TCPHandler: Code: 48. DB::Exception: Ordinary: RENAME DATABASE is not supported. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::IDatabase::renameDatabase(std::shared_ptr, String const&) @ 0x000000003291d486 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bc2f2a 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbf3aa 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:05:51.676063 [ 75386 ] {1a44e71e-8c53-429e-aec3-467da9e59638} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'nonexistentsomething' in scope SELECT nonexistentsomething. (UNKNOWN_IDENTIFIER) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:46492) (comment: 01083_expressions_in_engine_arguments.sql) (in query: -- The following line is needed just to disable checking stderr for emptiness SELECT nonexistentsomething;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 12:05:51.678802 [ 75386 ] {1a44e71e-8c53-429e-aec3-467da9e59638} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'nonexistentsomething' in scope SELECT nonexistentsomething. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000334f4e27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033448b8b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343f9f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d9740 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a542 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 2025.06.18 12:05:59.816864 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.06.18 12:06:00.337626 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} Cluster: Code: 198. DB::NetException: Not found address of host: localhosx. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000001ff9934a 3. ./build_docker/./src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000001ff81398 4. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000001ff7cbf4 5. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000001ff7dfe3 6. ./build_docker/./src/Common/DNSResolver.cpp:170: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000001ff800d2 7. ./contrib/llvm-project/libcxx/include/optional:272: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000336b94ce 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf35a 9. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 10. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000030708918 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:855: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a2512 14. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:06:07.828214 [ 703 ] {} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.06.18 12:06:08.345490 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} DNSResolver: Cannot resolve host (localhosy), error 0: Host not found. 2025.06.18 12:06:08.346002 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} Cluster: Code: 198. DB::NetException: Not found address of host: localhosy. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000001ff9934a 3. ./build_docker/./src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000001ff81398 4. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000001ff7cbf4 5. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000001ff7dfe3 6. ./build_docker/./src/Common/DNSResolver.cpp:170: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000001ff800d2 7. ./contrib/llvm-project/libcxx/include/optional:272: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000336b94ce 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf35a 9. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 10. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000030708918 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:855: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a2512 14. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b9fb7 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:06:17.197232 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.06.18 12:06:17.683144 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} Cluster: Code: 198. DB::NetException: Not found address of host: localhosx. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000001ff9934a 3. ./build_docker/./src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000001ff81398 4. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000001ff7cbf4 5. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000001ff7dfe3 6. ./build_docker/./src/Common/DNSResolver.cpp:170: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000001ff800d2 7. ./contrib/llvm-project/libcxx/include/optional:272: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000336b94ce 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf35a 9. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 10. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000030708918 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1650: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d257d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:06:25.691945 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} DNSResolver: Cannot resolve host (localhosy), error 0: Host not found. 2025.06.18 12:06:25.692340 [ 75386 ] {900e7165-d361-4f68-9f65-ee9d4dbd44f6} Cluster: Code: 198. DB::NetException: Not found address of host: localhosy. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000001ff9934a 3. ./build_docker/./src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000001ff81398 4. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000001ff7cbf4 5. ./build_docker/./src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000001ff7dfe3 6. ./build_docker/./src/Common/DNSResolver.cpp:170: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000001ff800d2 7. ./contrib/llvm-project/libcxx/include/optional:272: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000336b94ce 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000336bf35a 9. ./contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000336f354d 10. ./contrib/llvm-project/libcxx/include/vector:0: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000336db385 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fdd9916 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000030708918 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1650: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d257d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 25. ? @ 0x00007f8e6ce63ac3 26. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:06:33.694825 [ 841 ] {} DNSResolver: Cannot resolve host (localhosy), error 0: Host not found. 2025.06.18 12:06:41.697428 [ 841 ] {} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.06.18 12:06:42.078827 [ 2416 ] {fd8df352-61c8-413f-ae26-41adf70a22b4} StorageBuffer (test_9f6k2jua.buffer): Destination table test_9f6k2jua.file doesn't exist. Block of data is discarded. 2025.06.18 12:06:44.667555 [ 75386 ] {10cf81dd-8f4d-4c82-8d5d-68dedc335ce8} executeQuery: Code: 80. DB::Exception: Cannot MATERIALIZE TTL as there is no TTL set for table test_lptj2yyn.ttl (29918086-3b59-4b5c-9320-a42bfed63af3). (INCORRECT_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:35502) (comment: 01070_materialize_ttl.sql) (in query: alter table ttl materialize ttl;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:222: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485ab4f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:06:44.670858 [ 75386 ] {10cf81dd-8f4d-4c82-8d5d-68dedc335ce8} TCPHandler: Code: 80. DB::Exception: Cannot MATERIALIZE TTL as there is no TTL set for table test_lptj2yyn.ttl (29918086-3b59-4b5c-9320-a42bfed63af3). (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:222: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485ab4f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484f8f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.185536 [ 75386 ] {03a4b1d0-4a63-4f46-89f9-33d9facd9111} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39478) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.207581 [ 75386 ] {03a4b1d0-4a63-4f46-89f9-33d9facd9111} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.324630 [ 80770 ] {4f4d3aed-f6a6-4e7e-8f2f-7fab757c2129} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39482) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.353154 [ 80770 ] {4f4d3aed-f6a6-4e7e-8f2f-7fab757c2129} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.389516 [ 80757 ] {32b083b4-6423-4a3a-9436-96cc455051a9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict2' in scope SELECT * FROM database_for_dict.dict2. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39446) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict2 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.397367 [ 80757 ] {32b083b4-6423-4a3a-9436-96cc455051a9} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict2' in scope SELECT * FROM database_for_dict.dict2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.420868 [ 82140 ] {467cc995-e027-4158-a8f4-60393b3f01c0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39498) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.427310 [ 82140 ] {467cc995-e027-4158-a8f4-60393b3f01c0} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.431501 [ 82151 ] {fa298875-fc3c-4b85-b3ee-753df0c39d38} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39512) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.437622 [ 82151 ] {fa298875-fc3c-4b85-b3ee-753df0c39d38} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.441256 [ 82089 ] {6cb7c0a9-b97b-49b4-88a6-52b802b8e37e} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39484) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.461229 [ 82089 ] {6cb7c0a9-b97b-49b4-88a6-52b802b8e37e} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.468548 [ 81009 ] {0a63e6be-4e53-405a-9d93-8a3dd2da17c1} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39524) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.493256 [ 81009 ] {0a63e6be-4e53-405a-9d93-8a3dd2da17c1} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.590959 [ 82464 ] {e084e4bc-1b18-4d6c-9f2b-b29db8848f68} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38354) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.613097 [ 82464 ] {e084e4bc-1b18-4d6c-9f2b-b29db8848f68} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.633051 [ 73311 ] {e2ba45d6-2b56-4e99-bf99-23ef7374dcf1} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. Maybe you meant database_for_dict.dict1?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39400) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.633113 [ 80814 ] {1166ac5f-c7fc-43cb-9a55-9d665cbce11b} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. Maybe you meant database_for_dict.dict1?. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39456) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.638901 [ 80814 ] {1166ac5f-c7fc-43cb-9a55-9d665cbce11b} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. Maybe you meant database_for_dict.dict1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.652509 [ 73311 ] {e2ba45d6-2b56-4e99-bf99-23ef7374dcf1} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. Maybe you meant database_for_dict.dict1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008619c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0814c 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.772482 [ 80038 ] {d8b7cf5f-2239-497d-977e-11411476ba9f} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38364) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:31.817135 [ 80038 ] {d8b7cf5f-2239-497d-977e-11411476ba9f} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.185080 [ 73311 ] {d294c5ad-1b7f-49fd-adba-455bb0bef951} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38386) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.229150 [ 73311 ] {d294c5ad-1b7f-49fd-adba-455bb0bef951} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.316313 [ 80757 ] {f8aa8674-84d5-493e-aa39-2cf5cef3d032} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38422) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.329346 [ 80757 ] {f8aa8674-84d5-493e-aa39-2cf5cef3d032} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.455362 [ 75386 ] {2eba1a34-82e1-42c0-955f-fcce544c33a3} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38448) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.477250 [ 75386 ] {2eba1a34-82e1-42c0-955f-fcce544c33a3} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.532627 [ 80037 ] {6d9321c1-290e-4616-b90e-b5063d56eb55} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38462) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.557134 [ 80037 ] {6d9321c1-290e-4616-b90e-b5063d56eb55} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.606844 [ 80814 ] {0c797ef3-c3a0-457b-b095-2b7ec0948eb5} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38468) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.629210 [ 80814 ] {0c797ef3-c3a0-457b-b095-2b7ec0948eb5} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.638448 [ 81009 ] {ba145a47-fe5c-415f-a0e4-23911a351a53} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38472) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.648394 [ 81009 ] {ba145a47-fe5c-415f-a0e4-23911a351a53} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.729965 [ 82089 ] {4c9f900b-2e9c-40e5-805b-d7eb00a83d4e} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38480) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.751325 [ 80757 ] {5a7343ed-ff83-4e2c-9656-887dd5785302} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38496) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.757974 [ 80757 ] {5a7343ed-ff83-4e2c-9656-887dd5785302} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.765130 [ 82089 ] {4c9f900b-2e9c-40e5-805b-d7eb00a83d4e} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.781184 [ 82151 ] {9962d5dc-c13d-4760-91e9-96274cabfde1} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38518) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.797268 [ 82151 ] {9962d5dc-c13d-4760-91e9-96274cabfde1} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.914430 [ 82444 ] {8644a071-44d5-43c1-b9e5-abd2111292dc} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38532) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.919828 [ 82444 ] {8644a071-44d5-43c1-b9e5-abd2111292dc} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.933922 [ 82329 ] {a106b2af-00da-428f-8531-791d8ab493dc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38520) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.949854 [ 82329 ] {a106b2af-00da-428f-8531-791d8ab493dc} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:32.996233 [ 80038 ] {8bc47b29-fbeb-4603-996e-3a4b531c0597} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38544) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.021720 [ 80038 ] {8bc47b29-fbeb-4603-996e-3a4b531c0597} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.545626 [ 80037 ] {ec5da36a-f38d-48cf-8c62-3807d816a0f1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38610) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.567609 [ 80037 ] {ec5da36a-f38d-48cf-8c62-3807d816a0f1} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.577670 [ 73311 ] {7bf3f725-1ab4-410d-9a0c-a131bddc0291} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38598) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.617073 [ 73311 ] {7bf3f725-1ab4-410d-9a0c-a131bddc0291} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.723962 [ 80770 ] {db1d64e3-509b-4ad3-8242-23f22bf0b086} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38624) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.745320 [ 80770 ] {db1d64e3-509b-4ad3-8242-23f22bf0b086} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.763162 [ 82089 ] {33827c05-1260-469b-8e2a-c2da9ff18568} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38656) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.791315 [ 82089 ] {33827c05-1260-469b-8e2a-c2da9ff18568} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.784600 [ 81009 ] {5e02657b-8ca4-40c5-a5c2-31892552e912} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38640) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.810853 [ 81009 ] {5e02657b-8ca4-40c5-a5c2-31892552e912} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.902446 [ 82140 ] {e385fe8b-c5c6-4ad6-b307-cf21c919234d} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38664) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.933288 [ 82140 ] {e385fe8b-c5c6-4ad6-b307-cf21c919234d} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.938606 [ 82151 ] {537fc902-a5fe-48a8-8d5a-aed0c8af9492} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38680) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:33.954797 [ 82151 ] {537fc902-a5fe-48a8-8d5a-aed0c8af9492} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.117358 [ 82464 ] {bd3ab6f5-ca68-402f-a31e-b6aae3bfeafb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38696) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.124059 [ 82464 ] {bd3ab6f5-ca68-402f-a31e-b6aae3bfeafb} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.220759 [ 80038 ] {19036681-b27f-4f10-996f-76ae5de375ec} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38706) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.258275 [ 80038 ] {19036681-b27f-4f10-996f-76ae5de375ec} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.367599 [ 82429 ] {2cc9e227-2495-4357-be82-13bbb755238b} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38732) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.388098 [ 82099 ] {fe67a15c-5bff-4e83-b00e-b3ad04a75d0e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38716) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.431729 [ 82099 ] {fe67a15c-5bff-4e83-b00e-b3ad04a75d0e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.433279 [ 82429 ] {2cc9e227-2495-4357-be82-13bbb755238b} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.448732 [ 82151 ] {8a19553d-374b-4ad3-898f-0a226583c92b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38792) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.469369 [ 82151 ] {8a19553d-374b-4ad3-898f-0a226583c92b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.520863 [ 82329 ] {e3735993-d12f-4919-9ec2-faed9e562c65} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38748) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.541076 [ 82329 ] {e3735993-d12f-4919-9ec2-faed9e562c65} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.869871 [ 82151 ] {be0bf138-5f55-4e92-a130-45fad40da3cf} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38836) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.875424 [ 82151 ] {be0bf138-5f55-4e92-a130-45fad40da3cf} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.882800 [ 80038 ] {9bd6aebf-ea04-486a-8097-0d41712cdfc2} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38852) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.891244 [ 82329 ] {f4400013-749e-46d2-8418-f02e6338bf61} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38864) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.901210 [ 80038 ] {9bd6aebf-ea04-486a-8097-0d41712cdfc2} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.907105 [ 82099 ] {0db0dca5-d6cc-4d60-a8bf-a5a411422b69} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38876) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.924143 [ 82329 ] {f4400013-749e-46d2-8418-f02e6338bf61} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:34.929821 [ 82099 ] {0db0dca5-d6cc-4d60-a8bf-a5a411422b69} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.080375 [ 82429 ] {540594ca-5714-4662-ac18-2a4ba896c4d3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38892) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.121632 [ 82429 ] {540594ca-5714-4662-ac18-2a4ba896c4d3} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.144696 [ 75386 ] {b5569c61-f8e9-4a5a-80b7-d57a18ab181d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38908) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.151849 [ 75386 ] {b5569c61-f8e9-4a5a-80b7-d57a18ab181d} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.176731 [ 82444 ] {b0929a4f-36b8-4351-b475-0b48c8abc1ae} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38932) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.182825 [ 82444 ] {b0929a4f-36b8-4351-b475-0b48c8abc1ae} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.358088 [ 82329 ] {35e6a69a-dac9-4848-b5bc-83a935289b7d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38962) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.369439 [ 82329 ] {35e6a69a-dac9-4848-b5bc-83a935289b7d} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.422490 [ 82099 ] {a64c2afe-c45e-4028-b532-3183be8e0a64} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38980) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.443310 [ 82099 ] {a64c2afe-c45e-4028-b532-3183be8e0a64} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.446227 [ 82151 ] {80f15ff3-27d6-414a-b196-612be29ab792} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:38994) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.469760 [ 82151 ] {80f15ff3-27d6-414a-b196-612be29ab792} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.536164 [ 73311 ] {20804b41-e63b-42d0-8a3a-63e159e7ef1f} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39002) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.573321 [ 73311 ] {20804b41-e63b-42d0-8a3a-63e159e7ef1f} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.747009 [ 82329 ] {1549d26d-2dcb-4778-8237-3f7017180ba7} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39022) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.769124 [ 82329 ] {1549d26d-2dcb-4778-8237-3f7017180ba7} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.817307 [ 82464 ] {d3965d92-a2cf-4ae0-8d6d-f62bf818d625} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39048) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.840300 [ 82464 ] {d3965d92-a2cf-4ae0-8d6d-f62bf818d625} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.920706 [ 82429 ] {5bc5b783-e3af-420f-a4cf-389277706c23} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39058) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:35.941541 [ 82429 ] {5bc5b783-e3af-420f-a4cf-389277706c23} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.120358 [ 80814 ] {49008deb-45db-4d45-862b-8c92c693afe6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39090) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.143816 [ 80814 ] {49008deb-45db-4d45-862b-8c92c693afe6} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.191288 [ 80757 ] {dd837434-236a-45fa-8355-fcef4597ec9b} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39076) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.217083 [ 80757 ] {dd837434-236a-45fa-8355-fcef4597ec9b} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.236676 [ 81009 ] {05564ff8-de59-4b8f-9332-f4a060cfaa2e} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39106) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.261144 [ 81009 ] {05564ff8-de59-4b8f-9332-f4a060cfaa2e} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.291864 [ 82444 ] {102404a3-c91d-4fcb-a8f9-b8b845749edf} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39146) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.301305 [ 82444 ] {102404a3-c91d-4fcb-a8f9-b8b845749edf} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.328507 [ 82089 ] {47b02938-c53f-41bb-a2a5-4711604128c2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39144) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.373229 [ 82089 ] {47b02938-c53f-41bb-a2a5-4711604128c2} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.374054 [ 82429 ] {271cf7c2-ef35-46a8-aa01-b817543fc423} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39152) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.379731 [ 82429 ] {271cf7c2-ef35-46a8-aa01-b817543fc423} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.485104 [ 82464 ] {d359684f-1e7a-4fd8-babb-15423284e108} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39174) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.511178 [ 82464 ] {d359684f-1e7a-4fd8-babb-15423284e108} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.555481 [ 75386 ] {034e4340-5967-43e7-b9bc-201e6c6546f9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39178) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.577325 [ 75386 ] {034e4340-5967-43e7-b9bc-201e6c6546f9} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.844301 [ 80757 ] {31a2b25d-1a22-467d-80c0-a5e3aca1514f} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39196) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.865092 [ 80757 ] {31a2b25d-1a22-467d-80c0-a5e3aca1514f} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.878033 [ 80814 ] {52354dd8-430f-45b9-9f85-f79a23b294eb} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39198) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:36.897302 [ 80814 ] {52354dd8-430f-45b9-9f85-f79a23b294eb} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.036933 [ 82444 ] {eca632e2-a5ef-42bc-a61a-6d885ac24bfb} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39214) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.053009 [ 82444 ] {eca632e2-a5ef-42bc-a61a-6d885ac24bfb} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.085439 [ 82464 ] {586580e3-9ad6-49bf-b089-7953f75dd12c} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39222) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.121070 [ 82464 ] {586580e3-9ad6-49bf-b089-7953f75dd12c} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.129185 [ 75386 ] {096009c6-eac6-4407-80ad-65c04116e21d} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39250) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.149131 [ 75386 ] {096009c6-eac6-4407-80ad-65c04116e21d} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.184787 [ 82089 ] {a2e8c57a-4694-407a-926f-55e8d8a2f6c8} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39254) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.209057 [ 82089 ] {a2e8c57a-4694-407a-926f-55e8d8a2f6c8} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.327768 [ 80757 ] {0f8c0706-9068-4e00-b1ea-29cc18100ab7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39290) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.340565 [ 80814 ] {2a8e66be-70de-420b-8d61-aed143cea85d} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39276) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.351448 [ 80757 ] {0f8c0706-9068-4e00-b1ea-29cc18100ab7} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.355898 [ 80037 ] {b52340ca-4045-431b-b003-f3ac214de4f3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39278) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.381334 [ 80814 ] {2a8e66be-70de-420b-8d61-aed143cea85d} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.382582 [ 80037 ] {b52340ca-4045-431b-b003-f3ac214de4f3} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.482065 [ 82140 ] {78148469-db3b-4cc4-ac08-26a3fe1f499a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39306) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.509770 [ 82151 ] {bde00187-d5e7-4e7e-99a3-daa732393359} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39312) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.516913 [ 82140 ] {78148469-db3b-4cc4-ac08-26a3fe1f499a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.551339 [ 82151 ] {bde00187-d5e7-4e7e-99a3-daa732393359} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.830163 [ 73311 ] {9443810e-981f-4126-a955-a8826398abcc} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39356) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.850041 [ 73311 ] {9443810e-981f-4126-a955-a8826398abcc} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.868927 [ 82140 ] {68e0aa93-5c2a-4474-bc0e-4c14461a16b6} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39360) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.891423 [ 82140 ] {68e0aa93-5c2a-4474-bc0e-4c14461a16b6} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.921361 [ 82444 ] {d8ffd250-209f-4a60-b669-7c20dcec33f4} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39376) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.923262 [ 82329 ] {d84f2b14-8607-48a9-9558-e52d606a6c73} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39374) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.926603 [ 82444 ] {d8ffd250-209f-4a60-b669-7c20dcec33f4} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.934028 [ 80037 ] {30839aa1-d2dc-46cc-8e78-ca758cfebb00} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39396) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.937101 [ 82329 ] {d84f2b14-8607-48a9-9558-e52d606a6c73} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.960273 [ 80037 ] {30839aa1-d2dc-46cc-8e78-ca758cfebb00} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:37.986117 [ 82464 ] {e2578c38-dcda-4a27-8a38-156e92be1035} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39384) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.017337 [ 82464 ] {e2578c38-dcda-4a27-8a38-156e92be1035} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.151170 [ 82151 ] {f2cb7255-ab1a-4da0-a86e-07c814872256} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39422) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.154325 [ 82429 ] {5ca6619b-4a05-4dfa-a8d2-c38f5bbad129} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39426) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.179280 [ 82429 ] {5ca6619b-4a05-4dfa-a8d2-c38f5bbad129} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.193267 [ 82151 ] {f2cb7255-ab1a-4da0-a86e-07c814872256} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.414975 [ 73311 ] {16f0d924-63bd-4583-8120-159a9839eba2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39464) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.437213 [ 73311 ] {16f0d924-63bd-4583-8120-159a9839eba2} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.687143 [ 80038 ] {d9ae6e12-07f9-4bc5-9318-595abc782141} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39504) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.709578 [ 80038 ] {d9ae6e12-07f9-4bc5-9318-595abc782141} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.753323 [ 82151 ] {999402be-ff2d-4aa0-b9b4-09fcac0ff7a5} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39490) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.756398 [ 82140 ] {ca9daa70-46b5-4b05-b043-51f1cf93c73d} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39508) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.769165 [ 82151 ] {999402be-ff2d-4aa0-b9b4-09fcac0ff7a5} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.802211 [ 82140 ] {ca9daa70-46b5-4b05-b043-51f1cf93c73d} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.821434 [ 73311 ] {4dc4756e-775d-468e-9b59-271efd6995e1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39528) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.831258 [ 82464 ] {5d81a234-9d50-43e2-aaa4-04809e6e907a} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39544) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.845494 [ 73311 ] {4dc4756e-775d-468e-9b59-271efd6995e1} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.847147 [ 82329 ] {368ab5cd-8392-4ecb-bfa0-4fbf421401e0} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39546) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.849292 [ 82464 ] {5d81a234-9d50-43e2-aaa4-04809e6e907a} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.852084 [ 82329 ] {368ab5cd-8392-4ecb-bfa0-4fbf421401e0} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:38.995550 [ 82099 ] {117d4582-bbbd-4ad1-9b57-fb7d64a5d9e7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39558) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.023264 [ 82099 ] {117d4582-bbbd-4ad1-9b57-fb7d64a5d9e7} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.155019 [ 82429 ] {faf5c122-31f4-4678-bd6b-8da96defbb1f} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39574) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.174791 [ 82429 ] {faf5c122-31f4-4678-bd6b-8da96defbb1f} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.189183 [ 80038 ] {fe7bac66-f0a6-4782-bc60-1dac2cadfa58} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39576) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.205959 [ 73311 ] {8665e1a0-ac31-4e2e-b992-e35395d5cf29} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39606) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.211609 [ 73311 ] {8665e1a0-ac31-4e2e-b992-e35395d5cf29} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.239324 [ 80038 ] {fe7bac66-f0a6-4782-bc60-1dac2cadfa58} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.255891 [ 80757 ] {bca280ab-b8f6-4efb-a8e3-a30172bd253e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39628) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.284324 [ 80757 ] {bca280ab-b8f6-4efb-a8e3-a30172bd253e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.672581 [ 80757 ] {3bacef40-36e7-4565-a020-fc27f2cbb291} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39674) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.698471 [ 80814 ] {b7f118ea-4167-4236-8377-4a146b031429} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39658) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.700200 [ 80757 ] {3bacef40-36e7-4565-a020-fc27f2cbb291} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.745147 [ 80814 ] {b7f118ea-4167-4236-8377-4a146b031429} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.776127 [ 73311 ] {c219d414-4b8d-407a-b26d-cdd51197c62f} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39688) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.797257 [ 73311 ] {c219d414-4b8d-407a-b26d-cdd51197c62f} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.938475 [ 81009 ] {8b86b480-46c8-4999-b24b-0d599577eec5} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39694) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.960336 [ 81009 ] {8b86b480-46c8-4999-b24b-0d599577eec5} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:39.972163 [ 82140 ] {bbca91de-6516-4609-86ae-52e539f33e5b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39714) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.021163 [ 82140 ] {bbca91de-6516-4609-86ae-52e539f33e5b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.022999 [ 80038 ] {7d88a016-2488-4c42-aca5-a4a5b5fe3680} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39758) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.057828 [ 80038 ] {7d88a016-2488-4c42-aca5-a4a5b5fe3680} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.145188 [ 82151 ] {5f6cc27c-5320-41cf-bb3b-2de7f8ce1d7f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39790) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.165221 [ 82151 ] {5f6cc27c-5320-41cf-bb3b-2de7f8ce1d7f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.185547 [ 80757 ] {6f9e9c9b-d230-49a1-b87c-84309a2f1258} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39812) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.185632 [ 82089 ] {7c25384c-b70d-431f-a2b2-022bac5efac3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39774) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM database_for_dict.dict1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.207645 [ 80757 ] {6f9e9c9b-d230-49a1-b87c-84309a2f1258} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.213089 [ 82089 ] {7c25384c-b70d-431f-a2b2-022bac5efac3} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.dict1' in scope SELECT * FROM database_for_dict.dict1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.227424 [ 73311 ] {0ca38d5e-f125-433d-b6f4-9b9f15b1bb17} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39800) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.261120 [ 73311 ] {0ca38d5e-f125-433d-b6f4-9b9f15b1bb17} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.304813 [ 82099 ] {f24b4d46-bc01-475d-b331-c03bb4d96b84} executeQuery: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39820) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: DETACH DICTIONARY database_for_dict.dict1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.340257 [ 82099 ] {f24b4d46-bc01-475d-b331-c03bb4d96b84} TCPHandler: Code: 60. DB::Exception: Table database_for_dict.dict1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b07de1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000339930b3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a8587 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349288fb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492679f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034923c9d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349234b3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 20. ? @ 0x00007f8e6ce63ac3 21. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.353068 [ 82089 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39774, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.361988 [ 80037 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39642, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.364564 [ 80038 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39758, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.367906 [ 82099 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39820, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.370379 [ 80757 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39812, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.372323 [ 73311 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39800, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.373401 [ 82151 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39790, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abac99e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.484027 [ 75386 ] {68ed8f84-7555-47c0-ae56-ef1095d5d8d7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:39834). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:39834) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: SELECT * FROM system.dictionaries FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abe3b95 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1770 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.491498 [ 75386 ] {68ed8f84-7555-47c0-ae56-ef1095d5d8d7} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:39834). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:07:40.492123 [ 75386 ] {68ed8f84-7555-47c0-ae56-ef1095d5d8d7} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:39834). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abe3b95 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd1770 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:40.493241 [ 75386 ] {68ed8f84-7555-47c0-ae56-ef1095d5d8d7} TCPHandler: Client has gone away. 2025.06.18 12:07:46.782672 [ 73311 ] {415be33a-90fa-49fd-b973-4133de06a7fe} executeQuery: Code: 489. DB::Exception: Unknown key attribute 'non_existing_column': While processing PRIMARY KEY non_existing_column SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) LAYOUT(HASHED()). (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43192) (comment: 01018_ddl_dictionaries_bad_queries.sh) (in query: CREATE DICTIONARY dict1 ( key1 UInt64, key2 UInt64, value String ) PRIMARY KEY non_existing_column LAYOUT(HASHED()) SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:588: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328d91a4 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:46.788550 [ 73311 ] {415be33a-90fa-49fd-b973-4133de06a7fe} TCPHandler: Code: 489. DB::Exception: Unknown key attribute 'non_existing_column': While processing PRIMARY KEY non_existing_column SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) LAYOUT(HASHED()). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:588: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328d91a4 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:47.542457 [ 73311 ] {29fe48d8-ffa5-451a-8130-594c56c6143b} executeQuery: Code: 489. DB::Exception: Unknown key attribute 'non_existing_column': While processing PRIMARY KEY non_existing_column, key1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) LAYOUT(COMPLEX_KEY_HASHED()). (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43196) (comment: 01018_ddl_dictionaries_bad_queries.sh) (in query: CREATE DICTIONARY dict1 ( key1 UInt64, key2 UInt64, value String ) PRIMARY KEY non_existing_column, key1 LAYOUT(COMPLEX_KEY_HASHED()) SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:588: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328d91a4 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:47.548057 [ 73311 ] {29fe48d8-ffa5-451a-8130-594c56c6143b} TCPHandler: Code: 489. DB::Exception: Unknown key attribute 'non_existing_column': While processing PRIMARY KEY non_existing_column, key1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) LAYOUT(COMPLEX_KEY_HASHED()). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083bd10a 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:588: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328d91a4 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:48.855269 [ 73311 ] {f39f233a-fa69-47a8-a0cb-bd6b0ff55bde} executeQuery: Code: 489. DB::Exception: Cannot create dictionary with empty layout: While processing PRIMARY KEY key2, key1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10). (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43212) (comment: 01018_ddl_dictionaries_bad_queries.sh) (in query: CREATE DICTIONARY dict1 ( key1 UInt64, key2 UInt64, value String ) PRIMARY KEY key2, key1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328da5f2 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:48.864127 [ 73311 ] {f39f233a-fa69-47a8-a0cb-bd6b0ff55bde} TCPHandler: Code: 489. DB::Exception: Cannot create dictionary with empty layout: While processing PRIMARY KEY key2, key1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328da5f2 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:50.130930 [ 73311 ] {9401feab-f070-4d85-8fa8-45e95fa2a254} executeQuery: Code: 489. DB::Exception: Cannot create dictionary without primary key: While processing SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) LAYOUT(COMPLEX_KEY_HASHED()). (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43222) (comment: 01018_ddl_dictionaries_bad_queries.sh) (in query: CREATE DICTIONARY dict1 ( key1 UInt64, key2 UInt64, value String ) LAYOUT(COMPLEX_KEY_HASHED()) SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328da72c 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:50.137815 [ 73311 ] {9401feab-f070-4d85-8fa8-45e95fa2a254} TCPHandler: Code: 489. DB::Exception: Cannot create dictionary without primary key: While processing SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LIFETIME(MIN 1 MAX 10) LAYOUT(COMPLEX_KEY_HASHED()). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328da72c 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:51.356547 [ 73311 ] {74a2ba18-5684-403c-ae8b-db6220b38791} executeQuery: Code: 489. DB::Exception: Cannot create dictionary with empty lifetime: While processing PRIMARY KEY key2, key1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LAYOUT(COMPLEX_KEY_HASHED()). (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:43236) (comment: 01018_ddl_dictionaries_bad_queries.sh) (in query: CREATE DICTIONARY dict1 ( key1 UInt64, key2 UInt64, value String ) PRIMARY KEY key2, key1 LAYOUT(COMPLEX_KEY_HASHED()) SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328dba16 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:51.363084 [ 73311 ] {74a2ba18-5684-403c-ae8b-db6220b38791} TCPHandler: Code: 489. DB::Exception: Cannot create dictionary with empty lifetime: While processing PRIMARY KEY key2, key1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 USER 'default' TABLE 'table_for_dict1' DB 'test_ntsrpo6k')) LAYOUT(COMPLEX_KEY_HASHED()). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328dba16 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000328b79c3 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x00000000328b619d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x00000000328b47d9 8. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:42: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&) @ 0x00000000328b35e7 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000348dff1f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d21b6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 22. ? @ 0x00007f8e6ce63ac3 23. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:52.549247 [ 73311 ] {0449bc98-df53-47db-a955-e9d9960de957} executeQuery: Code: 489. DB::Exception: Cannot create dictionary with empty source. (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56866) (comment: 01018_ddl_dictionaries_bad_queries.sh) (in query: CREATE DICTIONARY dict1 ( key1 UInt64, key2 UInt64, value String ) PRIMARY KEY non_existing_column, key1 LAYOUT(COMPLEX_KEY_HASHED()) LIFETIME(MIN 1 MAX 10) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328da86c 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824b42c 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:52.555996 [ 73311 ] {0449bc98-df53-47db-a955-e9d9960de957} TCPHandler: Code: 489. DB::Exception: Cannot create dictionary with empty source. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d0a64 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x00000000328da86c 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824b42c 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382f2866 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d372c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 19. ? @ 0x00007f8e6ce63ac3 20. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:57.885661 [ 73311 ] {7e8f316f-2866-4ec7-9056-a0443455f881} executeQuery: Code: 57. DB::Exception: Table test_lazy_01014_concurrent_test_0yosyg9e.slog already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:56948) (comment: 01014_lazy_database_concurrent_recreate_reattach_and_show_tables.sh) (in query: ATTACH TABLE test_lazy_01014_concurrent_test_0yosyg9e.slog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:07:57.891112 [ 73311 ] {7e8f316f-2866-4ec7-9056-a0443455f881} TCPHandler: Code: 57. DB::Exception: Table test_lazy_01014_concurrent_test_0yosyg9e.slog already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:16.703478 [ 81009 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40792, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/VarInt.h:95: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x0000000020181528 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x00000000201f3d12 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000003abc8c73 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abab338 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:08:16.708910 [ 82089 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40800, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/VarInt.h:95: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x0000000020181528 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x00000000201f3d12 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000003abc8c73 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abab338 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 17. ? @ 0x00007f8e6ce63ac3 18. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:08:19.403319 [ 81009 ] {0801d156-b026-42e1-a1c6-f00f21f1a8fb} executeQuery: Code: 57. DB::Exception: Table test_lazy_01014_concurrent_test_0yosyg9e.tlog already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40818) (comment: 01014_lazy_database_concurrent_recreate_reattach_and_show_tables.sh) (in query: ATTACH TABLE test_lazy_01014_concurrent_test_0yosyg9e.tlog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:19.411375 [ 81009 ] {0801d156-b026-42e1-a1c6-f00f21f1a8fb} TCPHandler: Code: 57. DB::Exception: Table test_lazy_01014_concurrent_test_0yosyg9e.tlog already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838066d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348da8b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348be84a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:20.083184 [ 81009 ] {5e2dcdb0-f7e6-470f-b8f7-be7a7390082e} executeQuery: Code: 390. DB::Exception: Table `tlog2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:40834) (comment: 01014_lazy_database_concurrent_recreate_reattach_and_show_tables.sh) (in query: ATTACH TABLE test_lazy_01014_concurrent_test_0yosyg9e.tlog2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032954a26 5. ./src/Databases/IDatabase.h:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b5c3c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:20.088819 [ 81009 ] {5e2dcdb0-f7e6-470f-b8f7-be7a7390082e} TCPHandler: Code: 390. DB::Exception: Table `tlog2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032954a26 5. ./src/Databases/IDatabase.h:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b5c3c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e6556 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:25.713411 [ 81009 ] {42cf633f-1d05-464b-9207-5161170a4db0} InterpreterSystemQuery: SYNC REPLICA test_1nqp4t49.table_1013_2 (418da442-0c62-4cee-9c18-fbd38a00ea71): Timed out. 2025.06.18 12:08:26.094307 [ 81009 ] {42cf633f-1d05-464b-9207-5161170a4db0} executeQuery: Code: 159. DB::Exception: SYNC REPLICA test_1nqp4t49.table_1013_2 (418da442-0c62-4cee-9c18-fbd38a00ea71): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:50978) (comment: 01013_sync_replica_timeout_zookeeper.sh) (in query: SYSTEM SYNC REPLICA table_1013_2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1137: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000035978da8 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000003595538a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:26.102068 [ 81009 ] {42cf633f-1d05-464b-9207-5161170a4db0} TCPHandler: Code: 159. DB::Exception: SYNC REPLICA test_1nqp4t49.table_1013_2 (418da442-0c62-4cee-9c18-fbd38a00ea71): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e362a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1137: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000035978da8 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000003595538a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a5915 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 15. ? @ 0x00007f8e6ce63ac3 16. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:42.639026 [ 82329 ] {e14cfbee-03a8-4ccb-9371-7fbd917a6430} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:51282, local: [::1]:9000). (NETWORK_ERROR) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:51282) (comment: 01004_rename_deadlock.sh) (in query: SELECT * FROM system.tables), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003abe10f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0ee4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:42.650340 [ 82329 ] {e14cfbee-03a8-4ccb-9371-7fbd917a6430} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:51282). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c4518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ef517 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0349a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd506a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaf1a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 14. ? @ 0x00007f8e6ce63ac3 15. ? @ 0x00007f8e6cef5850 (version 24.8.14.10063.altinitytest (altinity build)) 2025.06.18 12:08:42.651023 [ 82329 ] {e14cfbee-03a8-4ccb-9371-7fbd917a6430} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:51282, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000204bfabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bd910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204be8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e69cd 6. DB::ReadBuffer::next() @ 0x00000000095b2aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003abe10f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd0ee4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abaea78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 16. ? @ 0x00007f8e6ce63ac3 17. ? @ 0x00007f8e6cef5850 2025.06.18 12:08:42.652257 [ 82329 ] {e14cfbee-03a8-4ccb-9371-7fbd917a6430} TCPHandler: Client has gone away. 2025.06.18 12:09:02.028487 [ 80814 ] {c49eceb8-d9a1-4395-b9fb-e9b784d138e2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54886) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:02.034830 [ 80814 ] {c49eceb8-d9a1-4395-b9fb-e9b784d138e2} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:03.794325 [ 82429 ] {e4689f04-cd5c-4942-9d99-a92982b3977e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:54926) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:03.799751 [ 82429 ] {e4689f04-cd5c-4942-9d99-a92982b3977e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:07.610873 [ 82429 ] {fb7f9854-90a5-493c-a452-2ee8623f02d4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55010) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:07.618579 [ 82429 ] {fb7f9854-90a5-493c-a452-2ee8623f02d4} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:08.398464 [ 82429 ] {dfdb70bb-0952-4009-84d9-34cb2abc73a6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:55038) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:08.405336 [ 82429 ] {dfdb70bb-0952-4009-84d9-34cb2abc73a6} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:13.217101 [ 82429 ] {ace9f48a-55b5-46eb-b787-8305dcdb2c56} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60898) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:13.226588 [ 82429 ] {ace9f48a-55b5-46eb-b787-8305dcdb2c56} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:13.973031 [ 82329 ] {65a91cb6-31d6-483e-9b25-070e17866b20} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60920) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:13.978933 [ 82329 ] {65a91cb6-31d6-483e-9b25-070e17866b20} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:14.726172 [ 82329 ] {8c7bbe3c-c02d-4ae2-894b-30a6f8c38a31} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60946) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:14.731728 [ 82329 ] {8c7bbe3c-c02d-4ae2-894b-30a6f8c38a31} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:15.479982 [ 82329 ] {9ae5aa9c-0d19-4a54-ac45-b4480935c279} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60962) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:15.485975 [ 82329 ] {9ae5aa9c-0d19-4a54-ac45-b4480935c279} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:16.233201 [ 82329 ] {02a11384-c55a-4af8-9eb7-00ae5a49ac2d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:60984) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:16.239219 [ 82329 ] {02a11384-c55a-4af8-9eb7-00ae5a49ac2d} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:19.937622 [ 82329 ] {8be8ea36-cedd-4a70-9380-0be913ed56cd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32862) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:19.943559 [ 82329 ] {8be8ea36-cedd-4a70-9380-0be913ed56cd} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:20.701336 [ 82429 ] {4bff2ee5-dfbf-49d3-b6de-1df858d4a0ce} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:32872) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:20.707142 [ 82429 ] {4bff2ee5-dfbf-49d3-b6de-1df858d4a0ce} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:22.419035 [ 82429 ] {4b72c0db-6bfb-468d-b89b-ccf356489386} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58052) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:22.425071 [ 82429 ] {4b72c0db-6bfb-468d-b89b-ccf356489386} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:23.186620 [ 82329 ] {12ab3273-a4c8-4ca2-b4ce-65e6decc3bb3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58082) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:23.192198 [ 82329 ] {12ab3273-a4c8-4ca2-b4ce-65e6decc3bb3} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:23.974639 [ 82329 ] {67295679-9892-4611-accb-ab6c6e5d7c08} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58112) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:23.980522 [ 82329 ] {67295679-9892-4611-accb-ab6c6e5d7c08} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:28.704732 [ 80038 ] {731db8d1-ac8e-4165-a5e9-0bcc2624777a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE) (version 24.8.14.10063.altinitytest (altinity build)) (from [::1]:58222) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:09:28.710464 [ 80038 ] {731db8d1-ac8e-4165-a5e9-0bcc2624777a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'view_00840' in scope SELECT * FROM view_00840 ORDER BY `table` ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c4669 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002fdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837bb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa07d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334de4ca 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342a1cd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033426f46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033425439 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034971e59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce3724 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdad6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce6195 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce5cf3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8140c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a26d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589729d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abae738 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac03951 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406049a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406058e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404e7675 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e404e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e0f11 23. ? @ 0x00007f8e6ce63ac3 24. ? @ 0x00007f8e6cef5850 2025.06.18 12:10:29.467283 [ 605 ] {} Application: Closed all listening sockets. Waiting for 27 outstanding connections. 2025.06.18 12:10:34.374199 [ 605 ] {} Application: Closed connections. But 9 remain. Tip: To increase wait time add to config: 60 2025.06.18 12:10:34.374993 [ 605 ] {} Application: Will shutdown forcefully.